├── .github └── ISSUE_TEMPLATE │ ├── bug_report.md │ ├── config.yml │ ├── design_considerations.md │ ├── feature_request.md │ ├── guide.md │ └── rc_feedback.md ├── .gitignore ├── .idea ├── codeStyleSettings.xml ├── codeStyles │ ├── Project.xml │ └── codeStyleConfig.xml ├── copyright │ └── profiles_settings.xml ├── dictionaries │ └── shared.xml ├── icon.png └── vcs.xml ├── CHANGES.md ├── CHANGES_UP_TO_1.7.md ├── CODE_OF_CONDUCT.md ├── CONTRIBUTING.md ├── LICENSE.txt ├── README.md ├── RELEASE.md ├── benchmarks ├── build.gradle.kts ├── scripts │ └── generate_plots_flow_flatten_merge.py └── src │ ├── jmh │ ├── java │ │ └── benchmarks │ │ │ └── flow │ │ │ └── scrabble │ │ │ ├── RxJava2PlaysScrabble.java │ │ │ ├── RxJava2PlaysScrabbleOpt.java │ │ │ └── optimizations │ │ │ ├── FlowableCharSequence.java │ │ │ ├── FlowableSplit.java │ │ │ └── StringFlowable.java │ ├── kotlin │ │ └── benchmarks │ │ │ ├── ChannelSinkBenchmark.kt │ │ │ ├── ChannelSinkDepthBenchmark.kt │ │ │ ├── ChannelSinkNoAllocationsBenchmark.kt │ │ │ ├── ParametrizedDispatcherBase.kt │ │ │ ├── SequentialSemaphoreBenchmark.kt │ │ │ ├── akka │ │ │ ├── PingPongAkkaBenchmark.kt │ │ │ └── StatefulActorAkkaBenchmark.kt │ │ │ ├── debug │ │ │ └── DebugSequenceOverheadBenchmark.kt │ │ │ ├── flow │ │ │ ├── CombineFlowsBenchmark.kt │ │ │ ├── CombineTwoFlowsBenchmark.kt │ │ │ ├── FlatMapMergeBenchmark.kt │ │ │ ├── FlowFlattenMergeBenchmark.kt │ │ │ ├── NumbersBenchmark.kt │ │ │ ├── SafeFlowBenchmark.kt │ │ │ ├── TakeBenchmark.kt │ │ │ └── scrabble │ │ │ │ ├── FlowPlaysScrabbleBase.kt │ │ │ │ ├── FlowPlaysScrabbleOpt.kt │ │ │ │ ├── IterableSpliterator.kt │ │ │ │ ├── README.md │ │ │ │ ├── ReactorPlaysScrabble.kt │ │ │ │ ├── SaneFlowPlaysScrabble.kt │ │ │ │ ├── SequencePlaysScrabble.kt │ │ │ │ └── ShakespearePlaysScrabble.kt │ │ │ └── scheduler │ │ │ ├── DispatchersContextSwitchBenchmark.kt │ │ │ ├── ForkJoinBenchmark.kt │ │ │ ├── LaunchBenchmark.kt │ │ │ ├── StatefulAwaitsBenchmark.kt │ │ │ └── actors │ │ │ ├── ConcurrentStatefulActorBenchmark.kt │ │ │ ├── CycledActorsBenchmark.kt │ │ │ ├── PingPongActorBenchmark.kt │ │ │ ├── PingPongWithBlockingContext.kt │ │ │ └── StatefulActorBenchmark.kt │ └── resources │ │ ├── ospd.txt.gz │ │ └── words.shakespeare.txt.gz │ └── main │ └── kotlin │ └── benchmarks │ └── common │ └── BenchmarkUtils.kt ├── bump-version.sh ├── coroutines-guide.md ├── docs ├── basics.md ├── cancellation-and-timeouts.md ├── cfg │ └── buildprofiles.xml ├── channels.md ├── compatibility.md ├── composing-suspending-functions.md ├── coroutine-context-and-dispatchers.md ├── coroutines-guide.md ├── debugging.md ├── exception-handling.md ├── flow.md ├── images │ ├── after.png │ ├── before.png │ ├── coroutine-breakpoint.png │ ├── coroutine-debug-1.png │ ├── coroutine-debug-2.png │ ├── coroutine-debug-3.png │ ├── coroutine-idea-debugging-1.png │ ├── coroutines-and-channels │ │ ├── aggregate.png │ │ ├── background.png │ │ ├── blocking.png │ │ ├── buffered-channel.png │ │ ├── callbacks.png │ │ ├── concurrency.png │ │ ├── conflated-channel.gif │ │ ├── generating-token.png │ │ ├── initial-window.png │ │ ├── loading.gif │ │ ├── progress-and-concurrency.png │ │ ├── progress.png │ │ ├── rendezvous-channel.png │ │ ├── run-configuration.png │ │ ├── suspend-requests.png │ │ ├── suspension-process.gif │ │ ├── time-comparison.png │ │ ├── unlimited-channel.png │ │ ├── using-channel-many-coroutines.png │ │ └── using-channel.png │ ├── coroutines-and-threads.svg │ ├── flow-breakpoint.png │ ├── flow-build-project.png │ ├── flow-debug-1.png │ ├── flow-debug-2.png │ ├── flow-debug-3.png │ ├── flow-debug-4.png │ ├── flow-debug-project.png │ ├── flow-resume-debug.png │ ├── new-gradle-project-jvm.png │ ├── parallelism-and-concurrency.svg │ ├── run-icon.png │ └── variable-optimised-out.png ├── kc.tree ├── knit.code.include ├── knit.test.template ├── select-expression.md ├── shared-mutable-state-and-concurrency.md ├── topics │ ├── cancellation-and-timeouts.md │ ├── channels.md │ ├── compatibility.md │ ├── composing-suspending-functions.md │ ├── coroutine-context-and-dispatchers.md │ ├── coroutines-and-channels.md │ ├── coroutines-basics.md │ ├── coroutines-guide.md │ ├── debug-coroutines-with-idea.md │ ├── debug-flow-with-idea.md │ ├── debugging.md │ ├── exception-handling.md │ ├── flow.md │ ├── knit.properties │ ├── select-expression.md │ └── shared-mutable-state-and-concurrency.md └── writerside.cfg ├── dokka-templates └── README.md ├── gradle.properties ├── gradle └── wrapper │ ├── gradle-wrapper.jar │ └── gradle-wrapper.properties ├── gradlew ├── gradlew.bat ├── integration-testing ├── .gitignore ├── README.md ├── build.gradle.kts ├── gradle.properties ├── gradle │ └── wrapper │ │ ├── gradle-wrapper.jar │ │ └── gradle-wrapper.properties ├── gradlew ├── gradlew.bat ├── java8Test │ ├── build.gradle.kts │ └── src │ │ └── test │ │ └── kotlin │ │ └── JUnit5TimeoutCompilation.kt ├── jpmsTest │ ├── build.gradle.kts │ └── src │ │ └── debugDynamicAgentJpmsTest │ │ ├── java │ │ └── module-info.java │ │ └── kotlin │ │ └── DynamicAttachDebugJpmsTest.kt ├── settings.gradle.kts ├── smokeTest │ ├── build.gradle.kts │ └── src │ │ ├── commonMain │ │ └── kotlin │ │ │ └── Sample.kt │ │ └── commonTest │ │ └── kotlin │ │ └── SampleTest.kt └── src │ ├── coreAgentTest │ └── kotlin │ │ └── CoreAgentTest.kt │ ├── debugAgentTest │ └── kotlin │ │ ├── DebugAgentTest.kt │ │ ├── DebugProbes.kt │ │ └── PrecompiledDebugProbesTest.kt │ ├── debugDynamicAgentTest │ └── kotlin │ │ └── DynamicAttachDebugTest.kt │ ├── jvmCoreTest │ └── kotlin │ │ ├── Jdk8InCoreIntegration.kt │ │ └── ListAllCoroutineThrowableSubclassesTest.kt │ └── mavenTest │ └── kotlin │ ├── MavenPublicationAtomicfuValidator.kt │ ├── MavenPublicationMetaInfValidator.kt │ └── MavenPublicationVersionValidator.kt ├── integration ├── README.md ├── kotlinx-coroutines-guava │ ├── README.md │ ├── api │ │ └── kotlinx-coroutines-guava.api │ ├── build.gradle.kts │ ├── package.list │ ├── src │ │ ├── ListenableFuture.kt │ │ └── module-info.java │ └── test │ │ ├── FutureAsDeferredUnhandledCompletionExceptionTest.kt │ │ ├── ListenableFutureExceptionsTest.kt │ │ ├── ListenableFutureTest.kt │ │ └── ListenableFutureToStringTest.kt ├── kotlinx-coroutines-jdk8 │ ├── README.md │ ├── api │ │ └── kotlinx-coroutines-jdk8.api │ ├── build.gradle.kts │ └── src │ │ └── module-info.java ├── kotlinx-coroutines-play-services │ ├── README.md │ ├── api │ │ └── kotlinx-coroutines-play-services.api │ ├── build.gradle.kts │ ├── package.list │ ├── src │ │ └── Tasks.kt │ └── test │ │ ├── FakeAndroid.kt │ │ └── TaskTest.kt └── kotlinx-coroutines-slf4j │ ├── README.md │ ├── api │ └── kotlinx-coroutines-slf4j.api │ ├── build.gradle.kts │ ├── package.list │ ├── src │ ├── MDCContext.kt │ └── module-info.java │ ├── test-resources │ └── logback-test.xml │ └── test │ └── MDCContextTest.kt ├── knit.properties ├── kotlinx-coroutines-bom └── build.gradle.kts ├── kotlinx-coroutines-core ├── README.md ├── api │ ├── kotlinx-coroutines-core.api │ └── kotlinx-coroutines-core.klib.api ├── benchmarks │ ├── README.md │ ├── jvm │ │ └── kotlin │ │ │ └── kotlinx │ │ │ └── coroutines │ │ │ ├── BenchmarkUtils.kt │ │ │ ├── SemaphoreBenchmark.kt │ │ │ ├── channels │ │ │ ├── ChannelProducerConsumerBenchmark.kt │ │ │ ├── SelectBenchmark.kt │ │ │ ├── SimpleChannel.kt │ │ │ └── SimpleChannelBenchmark.kt │ │ │ └── flow │ │ │ └── TakeWhileBenchmark.kt │ └── main │ │ └── kotlin │ │ └── SharedFlowBaseline.kt ├── build.gradle.kts ├── common │ ├── README.md │ ├── src │ │ ├── AbstractCoroutine.kt │ │ ├── Annotations.kt │ │ ├── Await.kt │ │ ├── Builders.common.kt │ │ ├── CancellableContinuation.kt │ │ ├── CancellableContinuationImpl.kt │ │ ├── CloseableCoroutineDispatcher.kt │ │ ├── CompletableDeferred.kt │ │ ├── CompletableJob.kt │ │ ├── CompletionHandler.common.kt │ │ ├── CompletionState.kt │ │ ├── CoroutineContext.common.kt │ │ ├── CoroutineDispatcher.kt │ │ ├── CoroutineExceptionHandler.kt │ │ ├── CoroutineName.kt │ │ ├── CoroutineScope.kt │ │ ├── CoroutineStart.kt │ │ ├── Debug.common.kt │ │ ├── Deferred.kt │ │ ├── Delay.kt │ │ ├── Dispatchers.common.kt │ │ ├── EventLoop.common.kt │ │ ├── Exceptions.common.kt │ │ ├── Guidance.kt │ │ ├── Job.kt │ │ ├── JobSupport.kt │ │ ├── MainCoroutineDispatcher.kt │ │ ├── NonCancellable.kt │ │ ├── Runnable.common.kt │ │ ├── SchedulerTask.common.kt │ │ ├── Supervisor.kt │ │ ├── Timeout.kt │ │ ├── Unconfined.kt │ │ ├── Waiter.kt │ │ ├── Yield.kt │ │ ├── channels │ │ │ ├── Broadcast.kt │ │ │ ├── BroadcastChannel.kt │ │ │ ├── BufferOverflow.kt │ │ │ ├── BufferedChannel.kt │ │ │ ├── Channel.kt │ │ │ ├── ChannelCoroutine.kt │ │ │ ├── Channels.common.kt │ │ │ ├── ConflatedBufferedChannel.kt │ │ │ ├── Deprecated.kt │ │ │ └── Produce.kt │ │ ├── flow │ │ │ ├── Builders.kt │ │ │ ├── Channels.kt │ │ │ ├── Flow.kt │ │ │ ├── FlowCollector.kt │ │ │ ├── Migration.kt │ │ │ ├── SharedFlow.kt │ │ │ ├── SharingStarted.kt │ │ │ ├── StateFlow.kt │ │ │ ├── internal │ │ │ │ ├── AbstractSharedFlow.kt │ │ │ │ ├── ChannelFlow.kt │ │ │ │ ├── Combine.kt │ │ │ │ ├── FlowCoroutine.kt │ │ │ │ ├── FlowExceptions.common.kt │ │ │ │ ├── Merge.kt │ │ │ │ ├── NopCollector.kt │ │ │ │ ├── NullSurrogate.kt │ │ │ │ ├── SafeCollector.common.kt │ │ │ │ └── SendingCollector.kt │ │ │ ├── operators │ │ │ │ ├── Context.kt │ │ │ │ ├── Delay.kt │ │ │ │ ├── Distinct.kt │ │ │ │ ├── Emitters.kt │ │ │ │ ├── Errors.kt │ │ │ │ ├── Limit.kt │ │ │ │ ├── Lint.kt │ │ │ │ ├── Merge.kt │ │ │ │ ├── Share.kt │ │ │ │ ├── Transform.kt │ │ │ │ └── Zip.kt │ │ │ └── terminal │ │ │ │ ├── Collect.kt │ │ │ │ ├── Collection.kt │ │ │ │ ├── Count.kt │ │ │ │ ├── Logic.kt │ │ │ │ └── Reduce.kt │ │ ├── internal │ │ │ ├── Concurrent.common.kt │ │ │ ├── ConcurrentLinkedList.kt │ │ │ ├── CoroutineExceptionHandlerImpl.common.kt │ │ │ ├── DispatchedContinuation.kt │ │ │ ├── DispatchedTask.kt │ │ │ ├── InlineList.kt │ │ │ ├── InternalAnnotations.common.kt │ │ │ ├── LimitedDispatcher.kt │ │ │ ├── LocalAtomics.common.kt │ │ │ ├── LockFreeLinkedList.common.kt │ │ │ ├── LockFreeTaskQueue.kt │ │ │ ├── MainDispatcherFactory.kt │ │ │ ├── NamedDispatcher.kt │ │ │ ├── OnUndeliveredElement.kt │ │ │ ├── ProbesSupport.common.kt │ │ │ ├── Scopes.kt │ │ │ ├── StackTraceRecovery.common.kt │ │ │ ├── Symbol.kt │ │ │ ├── Synchronized.common.kt │ │ │ ├── SystemProps.common.kt │ │ │ ├── ThreadContext.common.kt │ │ │ ├── ThreadLocal.common.kt │ │ │ └── ThreadSafeHeap.kt │ │ ├── intrinsics │ │ │ ├── Cancellable.kt │ │ │ └── Undispatched.kt │ │ ├── selects │ │ │ ├── OnTimeout.kt │ │ │ ├── Select.kt │ │ │ ├── SelectOld.kt │ │ │ ├── SelectUnbiased.kt │ │ │ └── WhileSelect.kt │ │ └── sync │ │ │ ├── Mutex.kt │ │ │ └── Semaphore.kt │ └── test │ │ ├── AbstractCoroutineTest.kt │ │ ├── AsyncLazyTest.kt │ │ ├── AsyncTest.kt │ │ ├── AtomicCancellationCommonTest.kt │ │ ├── AwaitCancellationTest.kt │ │ ├── AwaitTest.kt │ │ ├── BuilderContractsTest.kt │ │ ├── CancellableContinuationHandlersTest.kt │ │ ├── CancellableContinuationTest.kt │ │ ├── CancellableResumeOldTest.kt │ │ ├── CancellableResumeTest.kt │ │ ├── CancelledParentAttachTest.kt │ │ ├── CompletableDeferredTest.kt │ │ ├── CompletableJobTest.kt │ │ ├── CoroutineDispatcherOperatorFunInvokeTest.kt │ │ ├── CoroutineExceptionHandlerTest.kt │ │ ├── CoroutineScopeTest.kt │ │ ├── CoroutinesTest.kt │ │ ├── DelayDurationTest.kt │ │ ├── DelayTest.kt │ │ ├── DispatchedContinuationTest.kt │ │ ├── DurationToMillisTest.kt │ │ ├── EmptyContext.kt │ │ ├── FailedJobTest.kt │ │ ├── ImmediateYieldTest.kt │ │ ├── JobExtensionsTest.kt │ │ ├── JobStatesTest.kt │ │ ├── JobTest.kt │ │ ├── LaunchLazyTest.kt │ │ ├── LimitedParallelismSharedTest.kt │ │ ├── NonCancellableTest.kt │ │ ├── ParentCancellationTest.kt │ │ ├── SupervisorTest.kt │ │ ├── UnconfinedCancellationTest.kt │ │ ├── UnconfinedTest.kt │ │ ├── UndispatchedResultTest.kt │ │ ├── WithContextTest.kt │ │ ├── WithTimeoutDurationTest.kt │ │ ├── WithTimeoutOrNullDurationTest.kt │ │ ├── WithTimeoutOrNullTest.kt │ │ ├── WithTimeoutTest.kt │ │ ├── channels │ │ ├── BasicOperationsTest.kt │ │ ├── BroadcastChannelFactoryTest.kt │ │ ├── BroadcastTest.kt │ │ ├── BufferedBroadcastChannelTest.kt │ │ ├── BufferedChannelTest.kt │ │ ├── ChannelBufferOverflowTest.kt │ │ ├── ChannelFactoryTest.kt │ │ ├── ChannelReceiveCatchingTest.kt │ │ ├── ChannelUndeliveredElementFailureTest.kt │ │ ├── ChannelUndeliveredElementTest.kt │ │ ├── ChannelsTest.kt │ │ ├── ConflatedBroadcastChannelTest.kt │ │ ├── ConflatedChannelTest.kt │ │ ├── ConsumeTest.kt │ │ ├── ProduceConsumeTest.kt │ │ ├── ProduceTest.kt │ │ ├── RendezvousChannelTest.kt │ │ ├── SendReceiveStressTest.kt │ │ ├── TestBroadcastChannelKind.kt │ │ ├── TestChannelKind.kt │ │ └── UnlimitedChannelTest.kt │ │ ├── flow │ │ ├── BuildersTest.kt │ │ ├── FlowInvariantsTest.kt │ │ ├── IdFlowTest.kt │ │ ├── NamedDispatchers.kt │ │ ├── SafeFlowTest.kt │ │ ├── VirtualTime.kt │ │ ├── channels │ │ │ ├── ChannelBuildersFlowTest.kt │ │ │ ├── ChannelFlowTest.kt │ │ │ └── FlowCallbackTest.kt │ │ ├── internal │ │ │ └── FlowScopeTest.kt │ │ ├── operators │ │ │ ├── BooleanTerminationTest.kt │ │ │ ├── BufferConflationTest.kt │ │ │ ├── BufferTest.kt │ │ │ ├── CancellableTest.kt │ │ │ ├── CatchTest.kt │ │ │ ├── ChunkedTest.kt │ │ │ ├── CombineParametersTest.kt │ │ │ ├── CombineTest.kt │ │ │ ├── ConflateTest.kt │ │ │ ├── DebounceTest.kt │ │ │ ├── DistinctUntilChangedTest.kt │ │ │ ├── DropTest.kt │ │ │ ├── DropWhileTest.kt │ │ │ ├── FilterTest.kt │ │ │ ├── FilterTrivialTest.kt │ │ │ ├── FlatMapBaseTest.kt │ │ │ ├── FlatMapConcatTest.kt │ │ │ ├── FlatMapLatestTest.kt │ │ │ ├── FlatMapMergeBaseTest.kt │ │ │ ├── FlatMapMergeFastPathTest.kt │ │ │ ├── FlatMapMergeTest.kt │ │ │ ├── FlattenConcatTest.kt │ │ │ ├── FlattenMergeTest.kt │ │ │ ├── FlowContextOptimizationsTest.kt │ │ │ ├── FlowOnTest.kt │ │ │ ├── IndexedTest.kt │ │ │ ├── LintTest.kt │ │ │ ├── MapNotNullTest.kt │ │ │ ├── MapTest.kt │ │ │ ├── MergeTest.kt │ │ │ ├── OnCompletionTest.kt │ │ │ ├── OnEachTest.kt │ │ │ ├── OnEmptyTest.kt │ │ │ ├── OnStartTest.kt │ │ │ ├── RetryTest.kt │ │ │ ├── SampleTest.kt │ │ │ ├── ScanTest.kt │ │ │ ├── TakeTest.kt │ │ │ ├── TakeWhileTest.kt │ │ │ ├── TimeoutTest.kt │ │ │ ├── TransformLatestTest.kt │ │ │ ├── TransformTest.kt │ │ │ ├── TransformWhileTest.kt │ │ │ └── ZipTest.kt │ │ ├── sharing │ │ │ ├── ShareInBufferTest.kt │ │ │ ├── ShareInConflationTest.kt │ │ │ ├── ShareInFusionTest.kt │ │ │ ├── ShareInTest.kt │ │ │ ├── SharedFlowScenarioTest.kt │ │ │ ├── SharedFlowTest.kt │ │ │ ├── SharingStartedTest.kt │ │ │ ├── SharingStartedWhileSubscribedTest.kt │ │ │ ├── StateFlowTest.kt │ │ │ └── StateInTest.kt │ │ └── terminal │ │ │ ├── CollectLatestTest.kt │ │ │ ├── CountTest.kt │ │ │ ├── FirstTest.kt │ │ │ ├── FoldTest.kt │ │ │ ├── LastTest.kt │ │ │ ├── LaunchInTest.kt │ │ │ ├── ReduceTest.kt │ │ │ ├── SingleTest.kt │ │ │ └── ToCollectionTest.kt │ │ ├── selects │ │ ├── SelectBiasTest.kt │ │ ├── SelectBufferedChannelTest.kt │ │ ├── SelectDeferredTest.kt │ │ ├── SelectJobTest.kt │ │ ├── SelectLoopTest.kt │ │ ├── SelectMutexTest.kt │ │ ├── SelectOldTest.kt │ │ ├── SelectRendezvousChannelTest.kt │ │ ├── SelectTimeoutDurationTest.kt │ │ ├── SelectTimeoutTest.kt │ │ └── SelectUnlimitedChannelTest.kt │ │ └── sync │ │ ├── MutexTest.kt │ │ └── SemaphoreTest.kt ├── concurrent │ ├── src │ │ ├── Builders.concurrent.kt │ │ ├── Dispatchers.kt │ │ ├── MultithreadedDispatchers.common.kt │ │ ├── channels │ │ │ └── Channels.kt │ │ └── internal │ │ │ ├── LockFreeLinkedList.kt │ │ │ └── OnDemandAllocatingPool.kt │ └── test │ │ ├── AbstractDispatcherConcurrencyTest.kt │ │ ├── AtomicCancellationTest.kt │ │ ├── CommonThreadLocalTest.kt │ │ ├── ConcurrentExceptionsStressTest.kt │ │ ├── ConcurrentTestUtilities.common.kt │ │ ├── DefaultDispatchersConcurrencyTest.kt │ │ ├── JobStructuredJoinStressTest.kt │ │ ├── LimitedParallelismConcurrentTest.kt │ │ ├── MultithreadedDispatcherStressTest.kt │ │ ├── RunBlockingTest.kt │ │ ├── channels │ │ ├── BroadcastChannelSubStressTest.kt │ │ ├── ChannelCancelUndeliveredElementStressTest.kt │ │ ├── ConflatedBroadcastChannelNotifyStressTest.kt │ │ └── TrySendBlockingTest.kt │ │ ├── flow │ │ ├── CombineStressTest.kt │ │ ├── FlowCancellationTest.kt │ │ ├── StateFlowCommonStressTest.kt │ │ └── StateFlowUpdateCommonTest.kt │ │ ├── selects │ │ ├── SelectChannelStressTest.kt │ │ └── SelectMutexStressTest.kt │ │ └── sync │ │ ├── MutexStressTest.kt │ │ └── SemaphoreStressTest.kt ├── js │ ├── src │ │ ├── CoroutineContext.kt │ │ ├── Debug.kt │ │ ├── JSDispatcher.kt │ │ ├── Promise.kt │ │ ├── Window.kt │ │ └── internal │ │ │ ├── CopyOnWriteList.kt │ │ │ └── CoroutineExceptionHandlerImpl.kt │ └── test │ │ └── PromiseTest.kt ├── jsAndWasmJsShared │ ├── src │ │ ├── EventLoop.kt │ │ └── internal │ │ │ └── JSDispatcher.kt │ └── test │ │ ├── MessageQueueTest.kt │ │ └── SetTimeoutDispatcherTest.kt ├── jsAndWasmShared │ ├── src │ │ ├── CloseableCoroutineDispatcher.kt │ │ ├── CoroutineContext.kt │ │ ├── Dispatchers.kt │ │ ├── Exceptions.kt │ │ ├── Runnable.kt │ │ ├── SchedulerTask.kt │ │ ├── flow │ │ │ └── internal │ │ │ │ ├── FlowExceptions.kt │ │ │ │ └── SafeCollector.kt │ │ └── internal │ │ │ ├── Concurrent.kt │ │ │ ├── CoroutineExceptionHandlerImpl.kt │ │ │ ├── LinkedList.kt │ │ │ ├── LocalAtomics.kt │ │ │ ├── ProbesSupport.kt │ │ │ ├── StackTraceRecovery.kt │ │ │ ├── Synchronized.kt │ │ │ ├── SystemProps.kt │ │ │ ├── ThreadContext.kt │ │ │ └── ThreadLocal.kt │ └── test │ │ ├── ImmediateDispatcherTest.kt │ │ └── internal │ │ └── LinkedListTest.kt ├── jvm │ ├── resources │ │ ├── DebugProbesKt.bin │ │ └── META-INF │ │ │ ├── com.android.tools │ │ │ ├── proguard │ │ │ │ └── coroutines.pro │ │ │ └── r8 │ │ │ │ └── coroutines.pro │ │ │ └── proguard │ │ │ └── coroutines.pro │ ├── src │ │ ├── AbstractTimeSource.kt │ │ ├── Builders.kt │ │ ├── CoroutineContext.kt │ │ ├── Debug.kt │ │ ├── DebugStrings.kt │ │ ├── DefaultExecutor.kt │ │ ├── Dispatchers.kt │ │ ├── EventLoop.kt │ │ ├── Exceptions.kt │ │ ├── Executors.kt │ │ ├── Future.kt │ │ ├── Interruptible.kt │ │ ├── Runnable.kt │ │ ├── SchedulerTask.kt │ │ ├── ThreadContextElement.kt │ │ ├── ThreadPoolDispatcher.kt │ │ ├── channels │ │ │ ├── Actor.kt │ │ │ └── TickerChannels.kt │ │ ├── debug │ │ │ ├── CoroutineDebugging.kt │ │ │ └── internal │ │ │ │ ├── AgentInstallationType.kt │ │ │ │ ├── AgentPremain.kt │ │ │ │ ├── ConcurrentWeakMap.kt │ │ │ │ ├── DebugCoroutineInfo.kt │ │ │ │ ├── DebugCoroutineInfoImpl.kt │ │ │ │ ├── DebugProbes.kt │ │ │ │ ├── DebugProbesImpl.kt │ │ │ │ ├── DebuggerInfo.kt │ │ │ │ └── StackTraceFrame.kt │ │ ├── flow │ │ │ └── internal │ │ │ │ ├── FlowExceptions.kt │ │ │ │ └── SafeCollector.kt │ │ ├── future │ │ │ └── Future.kt │ │ ├── internal │ │ │ ├── Concurrent.kt │ │ │ ├── CoroutineExceptionHandlerImpl.kt │ │ │ ├── ExceptionsConstructor.kt │ │ │ ├── FastServiceLoader.kt │ │ │ ├── InternalAnnotations.kt │ │ │ ├── LocalAtomics.kt │ │ │ ├── MainDispatchers.kt │ │ │ ├── ProbesSupport.kt │ │ │ ├── ResizableAtomicArray.kt │ │ │ ├── StackTraceRecovery.kt │ │ │ ├── Synchronized.kt │ │ │ ├── SystemProps.kt │ │ │ ├── ThreadContext.kt │ │ │ └── ThreadLocal.kt │ │ ├── module-info.java │ │ ├── scheduling │ │ │ ├── CoroutineScheduler.kt │ │ │ ├── Dispatcher.kt │ │ │ ├── Tasks.kt │ │ │ └── WorkQueue.kt │ │ ├── stream │ │ │ └── Stream.kt │ │ └── time │ │ │ └── Time.kt │ ├── test-resources │ │ └── stacktraces │ │ │ ├── channels │ │ │ ├── testOfferFromScope.txt │ │ │ ├── testOfferWithContextWrapped.txt │ │ │ ├── testOfferWithCurrentContext.txt │ │ │ ├── testReceiveFromChannel.txt │ │ │ ├── testReceiveFromClosedChannel.txt │ │ │ ├── testSendFromScope.txt │ │ │ ├── testSendToChannel.txt │ │ │ └── testSendToClosedChannel.txt │ │ │ ├── resume-mode │ │ │ ├── testEventLoopDispatcher.txt │ │ │ ├── testEventLoopDispatcherSuspending.txt │ │ │ ├── testNestedEventLoopChangedContext.txt │ │ │ ├── testNestedEventLoopChangedContextSuspending.txt │ │ │ ├── testNestedEventLoopDispatcher.txt │ │ │ ├── testNestedEventLoopDispatcherSuspending.txt │ │ │ ├── testNestedUnconfined.txt │ │ │ ├── testNestedUnconfinedChangedContext.txt │ │ │ ├── testNestedUnconfinedChangedContextSuspending.txt │ │ │ ├── testNestedUnconfinedSuspending.txt │ │ │ ├── testUnconfined.txt │ │ │ └── testUnconfinedSuspending.txt │ │ │ ├── select │ │ │ ├── testSelectCompletedAwait.txt │ │ │ ├── testSelectJoin.txt │ │ │ └── testSelectOnReceive.txt │ │ │ └── timeout │ │ │ ├── testStacktraceIsRecoveredFromLexicalBlockWhenTriggeredByChild.txt │ │ │ ├── testStacktraceIsRecoveredFromSuspensionPoint.txt │ │ │ └── testStacktraceIsRecoveredFromSuspensionPointWithChild.txt │ └── test │ │ ├── AbstractLincheckTest.kt │ │ ├── AsyncJvmTest.kt │ │ ├── AwaitJvmTest.kt │ │ ├── AwaitStressTest.kt │ │ ├── CancellableContinuationJvmTest.kt │ │ ├── CancellableContinuationResumeCloseStressTest.kt │ │ ├── CancelledAwaitStressTest.kt │ │ ├── ConcurrentTestUtilities.kt │ │ ├── CoroutinesJvmTest.kt │ │ ├── DebugThreadNameTest.kt │ │ ├── DefaultExecutorStressTest.kt │ │ ├── DelayJvmTest.kt │ │ ├── DispatcherKeyTest.kt │ │ ├── DispatchersToStringTest.kt │ │ ├── EventLoopsTest.kt │ │ ├── ExecutorAsCoroutineDispatcherDelayTest.kt │ │ ├── ExecutorsTest.kt │ │ ├── FailFastOnStartTest.kt │ │ ├── FailingCoroutinesMachineryTest.kt │ │ ├── IODispatcherTest.kt │ │ ├── IntellijIdeaDebuggerEvaluatorCompatibilityTest.kt │ │ ├── JobActivationStressTest.kt │ │ ├── JobCancellationExceptionSerializerTest.kt │ │ ├── JobChildStressTest.kt │ │ ├── JobDisposeStressTest.kt │ │ ├── JobHandlersUpgradeStressTest.kt │ │ ├── JobOnCompletionStressTest.kt │ │ ├── JobStressTest.kt │ │ ├── JoinStressTest.kt │ │ ├── LimitedParallelismStressTest.kt │ │ ├── LimitedParallelismUnhandledExceptionTest.kt │ │ ├── MemoryFootprintTest.kt │ │ ├── MultithreadedDispatchersJvmTest.kt │ │ ├── MutexCancellationStressTest.kt │ │ ├── NoParamAssertionsTest.kt │ │ ├── RejectedExecutionTest.kt │ │ ├── ReusableCancellableContinuationInvariantStressTest.kt │ │ ├── ReusableCancellableContinuationLeakStressTest.kt │ │ ├── ReusableCancellableContinuationTest.kt │ │ ├── ReusableContinuationStressTest.kt │ │ ├── RunBlockingJvmTest.kt │ │ ├── RunInterruptibleStressTest.kt │ │ ├── RunInterruptibleTest.kt │ │ ├── TestBaseTest.kt │ │ ├── ThreadContextElementRestoreTest.kt │ │ ├── ThreadContextElementTest.kt │ │ ├── ThreadContextMutableCopiesTest.kt │ │ ├── ThreadContextOrderTest.kt │ │ ├── ThreadLocalStressTest.kt │ │ ├── ThreadLocalTest.kt │ │ ├── ThreadLocalsLeaksTest.kt │ │ ├── UnconfinedConcurrentStressTest.kt │ │ ├── VirtualTimeSource.kt │ │ ├── WithDefaultContextTest.kt │ │ ├── WithTimeoutChildDispatchStressTest.kt │ │ ├── WithTimeoutOrNullJvmTest.kt │ │ ├── WithTimeoutOrNullThreadDispatchTest.kt │ │ ├── WithTimeoutThreadDispatchTest.kt │ │ ├── channels │ │ ├── ActorLazyTest.kt │ │ ├── ActorTest.kt │ │ ├── BroadcastChannelLeakTest.kt │ │ ├── BroadcastChannelMultiReceiveStressTest.kt │ │ ├── BufferedChannelStressTest.kt │ │ ├── CancelledChannelLeakTest.kt │ │ ├── ChannelMemoryLeakStressTest.kt │ │ ├── ChannelSelectStressTest.kt │ │ ├── ChannelSendReceiveStressTest.kt │ │ ├── ChannelUndeliveredElementSelectOldStressTest.kt │ │ ├── ChannelUndeliveredElementStressTest.kt │ │ ├── ConflatedChannelCloseStressTest.kt │ │ ├── DoubleChannelCloseStressTest.kt │ │ ├── InvokeOnCloseStressTest.kt │ │ ├── ProduceConsumeJvmTest.kt │ │ ├── SendReceiveJvmStressTest.kt │ │ ├── SimpleSendReceiveJvmTest.kt │ │ ├── TickerChannelCommonTest.kt │ │ └── TickerChannelTest.kt │ │ ├── examples │ │ ├── example-delay-01.kt │ │ ├── example-delay-02.kt │ │ ├── example-delay-03.kt │ │ ├── example-delay-duration-01.kt │ │ ├── example-delay-duration-02.kt │ │ ├── example-delay-duration-03.kt │ │ ├── example-timeout-duration-01.kt │ │ └── test │ │ │ └── FlowDelayTest.kt │ │ ├── exceptions │ │ ├── CoroutineExceptionHandlerJvmTest.kt │ │ ├── FlowSuppressionTest.kt │ │ ├── JobBasicCancellationTest.kt │ │ ├── JobExceptionHandlingTest.kt │ │ ├── JobExceptionsStressTest.kt │ │ ├── JobNestedExceptionsTest.kt │ │ ├── ProduceExceptionsTest.kt │ │ ├── StackTraceRecoveryChannelsTest.kt │ │ ├── StackTraceRecoveryCustomExceptionsTest.kt │ │ ├── StackTraceRecoveryNestedScopesTest.kt │ │ ├── StackTraceRecoveryNestedTest.kt │ │ ├── StackTraceRecoveryResumeModeTest.kt │ │ ├── StackTraceRecoverySelectTest.kt │ │ ├── StackTraceRecoveryTest.kt │ │ ├── StackTraceRecoveryWithTimeoutTest.kt │ │ ├── Stacktraces.kt │ │ ├── SuppressionTests.kt │ │ ├── WithContextCancellationStressTest.kt │ │ └── WithContextExceptionHandlingTest.kt │ │ ├── flow │ │ ├── CallbackFlowTest.kt │ │ ├── ExceptionTransparencyTest.kt │ │ ├── FirstJvmTest.kt │ │ ├── FlatMapStressTest.kt │ │ ├── OnCompletionInterceptedReleaseTest.kt │ │ ├── SafeCollectorMemoryLeakTest.kt │ │ ├── SharedFlowStressTest.kt │ │ ├── SharingReferenceTest.kt │ │ ├── SharingStressTest.kt │ │ ├── StateFlowCancellabilityTest.kt │ │ ├── StateFlowStressTest.kt │ │ └── StateFlowUpdateStressTest.kt │ │ ├── guide │ │ ├── example-basic-01.kt │ │ ├── example-basic-02.kt │ │ ├── example-basic-03.kt │ │ ├── example-basic-04.kt │ │ ├── example-basic-05.kt │ │ ├── example-basic-06.kt │ │ ├── example-cancel-01.kt │ │ ├── example-cancel-02.kt │ │ ├── example-cancel-03.kt │ │ ├── example-cancel-04.kt │ │ ├── example-cancel-05.kt │ │ ├── example-cancel-06.kt │ │ ├── example-cancel-07.kt │ │ ├── example-cancel-08.kt │ │ ├── example-cancel-09.kt │ │ ├── example-cancel-10.kt │ │ ├── example-channel-01.kt │ │ ├── example-channel-02.kt │ │ ├── example-channel-03.kt │ │ ├── example-channel-04.kt │ │ ├── example-channel-05.kt │ │ ├── example-channel-06.kt │ │ ├── example-channel-07.kt │ │ ├── example-channel-08.kt │ │ ├── example-channel-09.kt │ │ ├── example-channel-10.kt │ │ ├── example-compose-01.kt │ │ ├── example-compose-02.kt │ │ ├── example-compose-03.kt │ │ ├── example-compose-04.kt │ │ ├── example-compose-05.kt │ │ ├── example-compose-06.kt │ │ ├── example-context-01.kt │ │ ├── example-context-02.kt │ │ ├── example-context-03.kt │ │ ├── example-context-04.kt │ │ ├── example-context-05.kt │ │ ├── example-context-06.kt │ │ ├── example-context-07.kt │ │ ├── example-context-08.kt │ │ ├── example-context-09.kt │ │ ├── example-context-10.kt │ │ ├── example-context-11.kt │ │ ├── example-exceptions-01.kt │ │ ├── example-exceptions-02.kt │ │ ├── example-exceptions-03.kt │ │ ├── example-exceptions-04.kt │ │ ├── example-exceptions-05.kt │ │ ├── example-exceptions-06.kt │ │ ├── example-flow-01.kt │ │ ├── example-flow-02.kt │ │ ├── example-flow-03.kt │ │ ├── example-flow-04.kt │ │ ├── example-flow-05.kt │ │ ├── example-flow-06.kt │ │ ├── example-flow-07.kt │ │ ├── example-flow-08.kt │ │ ├── example-flow-09.kt │ │ ├── example-flow-10.kt │ │ ├── example-flow-11.kt │ │ ├── example-flow-12.kt │ │ ├── example-flow-13.kt │ │ ├── example-flow-14.kt │ │ ├── example-flow-15.kt │ │ ├── example-flow-16.kt │ │ ├── example-flow-17.kt │ │ ├── example-flow-18.kt │ │ ├── example-flow-19.kt │ │ ├── example-flow-20.kt │ │ ├── example-flow-21.kt │ │ ├── example-flow-22.kt │ │ ├── example-flow-23.kt │ │ ├── example-flow-24.kt │ │ ├── example-flow-25.kt │ │ ├── example-flow-26.kt │ │ ├── example-flow-27.kt │ │ ├── example-flow-28.kt │ │ ├── example-flow-29.kt │ │ ├── example-flow-30.kt │ │ ├── example-flow-31.kt │ │ ├── example-flow-32.kt │ │ ├── example-flow-33.kt │ │ ├── example-flow-34.kt │ │ ├── example-flow-35.kt │ │ ├── example-flow-36.kt │ │ ├── example-flow-37.kt │ │ ├── example-flow-38.kt │ │ ├── example-flow-39.kt │ │ ├── example-select-01.kt │ │ ├── example-select-02.kt │ │ ├── example-select-03.kt │ │ ├── example-select-04.kt │ │ ├── example-select-05.kt │ │ ├── example-supervision-01.kt │ │ ├── example-supervision-02.kt │ │ ├── example-supervision-03.kt │ │ ├── example-sync-01.kt │ │ ├── example-sync-02.kt │ │ ├── example-sync-03.kt │ │ ├── example-sync-04.kt │ │ ├── example-sync-05.kt │ │ ├── example-sync-06.kt │ │ ├── example-sync-07.kt │ │ └── test │ │ │ ├── BasicsGuideTest.kt │ │ │ ├── CancellationGuideTest.kt │ │ │ ├── ChannelsGuideTest.kt │ │ │ ├── ComposingGuideTest.kt │ │ │ ├── DispatcherGuideTest.kt │ │ │ ├── ExceptionsGuideTest.kt │ │ │ ├── FlowGuideTest.kt │ │ │ ├── SelectGuideTest.kt │ │ │ └── SharedStateGuideTest.kt │ │ ├── internal │ │ ├── ConcurrentWeakMapCollectionStressTest.kt │ │ ├── ConcurrentWeakMapOperationStressTest.kt │ │ ├── ConcurrentWeakMapTest.kt │ │ ├── FastServiceLoaderTest.kt │ │ ├── LockFreeLinkedListLongStressTest.kt │ │ ├── LockFreeTaskQueueStressTest.kt │ │ ├── LockFreeTaskQueueTest.kt │ │ ├── OnDemandAllocatingPoolLincheckTest.kt │ │ ├── ThreadSafeHeapStressTest.kt │ │ └── ThreadSafeHeapTest.kt │ │ ├── jdk8 │ │ ├── future │ │ │ ├── AsFutureTest.kt │ │ │ ├── FutureAsDeferredUnhandledCompletionExceptionTest.kt │ │ │ ├── FutureExceptionsTest.kt │ │ │ └── FutureTest.kt │ │ ├── stream │ │ │ └── ConsumeAsFlowTest.kt │ │ └── time │ │ │ ├── DurationOverflowTest.kt │ │ │ ├── FlowDebounceTest.kt │ │ │ ├── FlowSampleTest.kt │ │ │ └── WithTimeoutTest.kt │ │ ├── knit │ │ ├── ClosedAfterGuideTestExecutor.kt │ │ └── TestUtil.kt │ │ ├── lincheck │ │ ├── ChannelsLincheckTest.kt │ │ ├── LockFreeTaskQueueLincheckTest.kt │ │ ├── MutexLincheckTest.kt │ │ ├── ResizableAtomicArrayLincheckTest.kt │ │ └── SemaphoreLincheckTest.kt │ │ ├── scheduling │ │ ├── BlockingCoroutineDispatcherLivenessStressTest.kt │ │ ├── BlockingCoroutineDispatcherMixedStealingStressTest.kt │ │ ├── BlockingCoroutineDispatcherTerminationStressTest.kt │ │ ├── BlockingCoroutineDispatcherTest.kt │ │ ├── BlockingCoroutineDispatcherThreadLimitStressTest.kt │ │ ├── BlockingCoroutineDispatcherWorkSignallingStressTest.kt │ │ ├── CoroutineDispatcherTest.kt │ │ ├── CoroutineSchedulerCloseStressTest.kt │ │ ├── CoroutineSchedulerInternalApiStressTest.kt │ │ ├── CoroutineSchedulerLivenessStressTest.kt │ │ ├── CoroutineSchedulerOversubscriptionTest.kt │ │ ├── CoroutineSchedulerStressTest.kt │ │ ├── CoroutineSchedulerTest.kt │ │ ├── DefaultDispatchersTest.kt │ │ ├── LimitingCoroutineDispatcherStressTest.kt │ │ ├── LimitingDispatcherTest.kt │ │ ├── SchedulerTestBase.kt │ │ ├── SharingWorkerClassTest.kt │ │ ├── TestTimeSource.kt │ │ ├── WorkQueueStressTest.kt │ │ └── WorkQueueTest.kt │ │ └── selects │ │ ├── SelectDeadlockStressTest.kt │ │ ├── SelectMemoryLeakStressTest.kt │ │ └── SelectPhilosophersStressTest.kt ├── knit.properties ├── native │ ├── src │ │ ├── Builders.kt │ │ ├── CloseableCoroutineDispatcher.kt │ │ ├── CoroutineContext.kt │ │ ├── Debug.kt │ │ ├── Dispatchers.kt │ │ ├── EventLoop.kt │ │ ├── Exceptions.kt │ │ ├── MultithreadedDispatchers.kt │ │ ├── Runnable.kt │ │ ├── SchedulerTask.kt │ │ ├── flow │ │ │ └── internal │ │ │ │ ├── FlowExceptions.kt │ │ │ │ └── SafeCollector.kt │ │ └── internal │ │ │ ├── Concurrent.kt │ │ │ ├── CopyOnWriteList.kt │ │ │ ├── CoroutineExceptionHandlerImpl.kt │ │ │ ├── LocalAtomics.kt │ │ │ ├── ProbesSupport.kt │ │ │ ├── StackTraceRecovery.kt │ │ │ ├── Synchronized.kt │ │ │ ├── SystemProps.kt │ │ │ ├── ThreadContext.kt │ │ │ └── ThreadLocal.kt │ └── test │ │ ├── ConcurrentTestUtilities.kt │ │ ├── DelayExceptionTest.kt │ │ ├── MultithreadedDispatchersTest.kt │ │ └── WorkerTest.kt ├── nativeDarwin │ ├── src │ │ └── Dispatchers.kt │ └── test │ │ ├── Launcher.kt │ │ └── MainDispatcherTest.kt ├── nativeOther │ ├── src │ │ └── Dispatchers.kt │ └── test │ │ └── Launcher.kt ├── wasmJs │ ├── src │ │ ├── CoroutineContext.kt │ │ ├── Debug.kt │ │ ├── JSDispatcher.kt │ │ ├── Promise.kt │ │ └── internal │ │ │ ├── CopyOnWriteList.kt │ │ │ └── CoroutineExceptionHandlerImpl.kt │ └── test │ │ └── PromiseTest.kt └── wasmWasi │ └── src │ ├── Debug.kt │ ├── EventLoop.kt │ └── internal │ ├── CoroutineExceptionHandlerImpl.kt │ └── CoroutineRunner.kt ├── kotlinx-coroutines-debug ├── README.md ├── api │ └── kotlinx-coroutines-debug.api ├── build.gradle.kts ├── resources │ └── META-INF │ │ └── services │ │ └── reactor.blockhound.integration.BlockHoundIntegration ├── src │ ├── Attach.kt │ ├── CoroutineInfo.kt │ ├── CoroutinesBlockHoundIntegration.kt │ ├── DebugProbes.kt │ ├── NoOpProbes.kt │ ├── junit │ │ ├── CoroutinesTimeoutImpl.kt │ │ ├── junit4 │ │ │ ├── CoroutinesTimeout.kt │ │ │ └── CoroutinesTimeoutStatement.kt │ │ └── junit5 │ │ │ ├── CoroutinesTimeout.kt │ │ │ └── CoroutinesTimeoutExtension.kt │ └── module-info.java └── test │ ├── BlockHoundTest.kt │ ├── CoroutinesDumpTest.kt │ ├── DebugLeaksTest.kt │ ├── DebugProbesTest.kt │ ├── DebugTestBase.kt │ ├── DumpCoroutineInfoAsJsonAndReferencesTest.kt │ ├── DumpWithCreationStackTraceTest.kt │ ├── EnhanceStackTraceWithTreadDumpAsJsonTest.kt │ ├── Example.kt │ ├── LazyCoroutineTest.kt │ ├── RecoveryExample.kt │ ├── RunningThreadStackMergeTest.kt │ ├── SanitizedProbesTest.kt │ ├── ScopedBuildersTest.kt │ ├── StacktraceUtils.kt │ ├── StandardBuildersDebugTest.kt │ ├── StartModeProbesTest.kt │ ├── TestRuleExample.kt │ ├── ToStringTest.kt │ ├── WithContextUndispatchedTest.kt │ ├── junit4 │ ├── CoroutinesTimeoutDisabledTracesTest.kt │ ├── CoroutinesTimeoutEagerTest.kt │ ├── CoroutinesTimeoutTest.kt │ └── TestFailureValidation.kt │ └── junit5 │ ├── CoroutinesTimeoutExtensionTest.kt │ ├── CoroutinesTimeoutInheritanceTest.kt │ ├── CoroutinesTimeoutMethodTest.kt │ ├── CoroutinesTimeoutNestedTest.kt │ ├── CoroutinesTimeoutSimpleTest.kt │ ├── CoroutinesTimeoutTest.kt │ └── RegisterExtensionExample.kt ├── kotlinx-coroutines-test ├── MIGRATION.md ├── README.md ├── api │ ├── kotlinx-coroutines-test.api │ └── kotlinx-coroutines-test.klib.api ├── build.gradle.kts ├── common │ ├── src │ │ ├── TestBuilders.kt │ │ ├── TestCoroutineDispatchers.kt │ │ ├── TestCoroutineScheduler.kt │ │ ├── TestDispatcher.kt │ │ ├── TestDispatchers.kt │ │ ├── TestScope.kt │ │ └── internal │ │ │ ├── ExceptionCollector.kt │ │ │ ├── ReportingSupervisorJob.kt │ │ │ └── TestMainDispatcher.kt │ └── test │ │ ├── Helpers.kt │ │ ├── RunTestTest.kt │ │ ├── StandardTestDispatcherTest.kt │ │ ├── TestCoroutineSchedulerTest.kt │ │ ├── TestDispatchersTest.kt │ │ ├── TestScopeTest.kt │ │ └── UnconfinedTestDispatcherTest.kt ├── js │ ├── src │ │ ├── TestBuilders.kt │ │ └── internal │ │ │ ├── JsPromiseInterfaceForTesting.kt │ │ │ └── TestMainDispatcher.kt │ └── test │ │ ├── Helpers.kt │ │ └── PromiseTest.kt ├── jvm │ ├── resources │ │ └── META-INF │ │ │ ├── proguard │ │ │ └── coroutines.pro │ │ │ └── services │ │ │ ├── kotlinx.coroutines.CoroutineExceptionHandler │ │ │ └── kotlinx.coroutines.internal.MainDispatcherFactory │ ├── src │ │ ├── TestBuildersJvm.kt │ │ ├── internal │ │ │ └── TestMainDispatcherJvm.kt │ │ ├── migration │ │ │ ├── TestBuildersDeprecated.kt │ │ │ ├── TestCoroutineDispatcher.kt │ │ │ ├── TestCoroutineExceptionHandler.kt │ │ │ └── TestCoroutineScope.kt │ │ └── module-info.java │ └── test │ │ ├── DumpOnTimeoutTest.kt │ │ ├── HelpersJvm.kt │ │ ├── MemoryLeakTest.kt │ │ ├── MultithreadingTest.kt │ │ ├── RunTestStressTest.kt │ │ ├── UncaughtExceptionsTest.kt │ │ └── migration │ │ ├── RunBlockingTestOnTestScopeTest.kt │ │ ├── RunTestLegacyScopeTest.kt │ │ ├── TestBuildersTest.kt │ │ ├── TestCoroutineDispatcherTest.kt │ │ ├── TestCoroutineScopeTest.kt │ │ ├── TestRunBlockingOrderTest.kt │ │ └── TestRunBlockingTest.kt ├── native │ ├── src │ │ ├── TestBuilders.kt │ │ └── internal │ │ │ └── TestMainDispatcher.kt │ └── test │ │ └── Helpers.kt ├── npm │ ├── README.md │ └── package.json ├── wasmJs │ ├── src │ │ ├── TestBuilders.kt │ │ └── internal │ │ │ ├── JsPromiseInterfaceForTesting.kt │ │ │ └── TestMainDispatcher.kt │ └── test │ │ ├── Helpers.kt │ │ └── PromiseTest.kt └── wasmWasi │ ├── src │ ├── TestBuilders.kt │ └── internal │ │ └── TestMainDispatcher.kt │ └── test │ └── Helpers.kt ├── license └── NOTICE.txt ├── reactive ├── README.md ├── knit.properties ├── knit.test.include ├── kotlinx-coroutines-jdk9 │ ├── README.md │ ├── api │ │ └── kotlinx-coroutines-jdk9.api │ ├── build.gradle.kts │ ├── package.list │ ├── src │ │ ├── Await.kt │ │ ├── Publish.kt │ │ ├── ReactiveFlow.kt │ │ └── module-info.java │ └── test │ │ ├── AwaitTest.kt │ │ ├── FlowAsPublisherTest.kt │ │ ├── IntegrationTest.kt │ │ ├── PublishTest.kt │ │ ├── PublisherAsFlowTest.kt │ │ ├── PublisherBackpressureTest.kt │ │ ├── PublisherCollectTest.kt │ │ ├── PublisherCompletionStressTest.kt │ │ └── PublisherMultiTest.kt ├── kotlinx-coroutines-reactive │ ├── README.md │ ├── api │ │ └── kotlinx-coroutines-reactive.api │ ├── build.gradle.kts │ ├── package.list │ ├── src │ │ ├── Await.kt │ │ ├── Channel.kt │ │ ├── ContextInjector.kt │ │ ├── Convert.kt │ │ ├── Migration.kt │ │ ├── Publish.kt │ │ ├── ReactiveFlow.kt │ │ └── module-info.java │ └── test │ │ ├── AwaitCancellationStressTest.kt │ │ ├── AwaitTest.kt │ │ ├── CancelledParentAttachTest.kt │ │ ├── FlowAsPublisherTest.kt │ │ ├── IntegrationTest.kt │ │ ├── IterableFlowTckTest.kt │ │ ├── PublishTest.kt │ │ ├── PublisherAsFlowTest.kt │ │ ├── PublisherBackpressureTest.kt │ │ ├── PublisherCollectTest.kt │ │ ├── PublisherCompletionStressTest.kt │ │ ├── PublisherMultiTest.kt │ │ ├── PublisherRequestStressTest.kt │ │ ├── PublisherSubscriptionSelectTest.kt │ │ ├── RangePublisherBufferedTest.kt │ │ ├── RangePublisherTest.kt │ │ ├── ReactiveStreamTckTest.kt │ │ └── UnboundedIntegerIncrementPublisherTest.kt ├── kotlinx-coroutines-reactor │ ├── README.md │ ├── api │ │ └── kotlinx-coroutines-reactor.api │ ├── build.gradle.kts │ ├── package.list │ ├── resources │ │ └── META-INF │ │ │ └── services │ │ │ └── kotlinx.coroutines.reactive.ContextInjector │ ├── src │ │ ├── Convert.kt │ │ ├── Flux.kt │ │ ├── Migration.kt │ │ ├── Mono.kt │ │ ├── ReactorContext.kt │ │ ├── ReactorContextInjector.kt │ │ ├── ReactorFlow.kt │ │ ├── Scheduler.kt │ │ └── module-info.java │ └── test │ │ ├── BackpressureTest.kt │ │ ├── Check.kt │ │ ├── ConvertTest.kt │ │ ├── FlowAsFluxTest.kt │ │ ├── FluxCompletionStressTest.kt │ │ ├── FluxContextTest.kt │ │ ├── FluxMultiTest.kt │ │ ├── FluxSingleTest.kt │ │ ├── FluxTest.kt │ │ ├── MonoAwaitStressTest.kt │ │ ├── MonoTest.kt │ │ ├── ReactorContextTest.kt │ │ └── SchedulerTest.kt ├── kotlinx-coroutines-rx2 │ ├── README.md │ ├── api │ │ └── kotlinx-coroutines-rx2.api │ ├── build.gradle.kts │ ├── package.list │ ├── src │ │ ├── RxAwait.kt │ │ ├── RxCancellable.kt │ │ ├── RxChannel.kt │ │ ├── RxCompletable.kt │ │ ├── RxConvert.kt │ │ ├── RxFlowable.kt │ │ ├── RxMaybe.kt │ │ ├── RxObservable.kt │ │ ├── RxScheduler.kt │ │ ├── RxSingle.kt │ │ └── module-info.java │ └── test │ │ ├── BackpressureTest.kt │ │ ├── Check.kt │ │ ├── CompletableTest.kt │ │ ├── ConvertTest.kt │ │ ├── FlowAsFlowableTest.kt │ │ ├── FlowAsObservableTest.kt │ │ ├── FlowableContextTest.kt │ │ ├── FlowableExceptionHandlingTest.kt │ │ ├── FlowableTest.kt │ │ ├── IntegrationTest.kt │ │ ├── IterableFlowAsFlowableTckTest.kt │ │ ├── LeakedExceptionTest.kt │ │ ├── MaybeTest.kt │ │ ├── ObservableAsFlowTest.kt │ │ ├── ObservableCollectTest.kt │ │ ├── ObservableCompletionStressTest.kt │ │ ├── ObservableExceptionHandlingTest.kt │ │ ├── ObservableMultiTest.kt │ │ ├── ObservableSingleTest.kt │ │ ├── ObservableSourceAsFlowStressTest.kt │ │ ├── ObservableSubscriptionSelectTest.kt │ │ ├── ObservableTest.kt │ │ ├── SchedulerStressTest.kt │ │ ├── SchedulerTest.kt │ │ └── SingleTest.kt └── kotlinx-coroutines-rx3 │ ├── README.md │ ├── api │ └── kotlinx-coroutines-rx3.api │ ├── build.gradle.kts │ ├── package.list │ ├── src │ ├── RxAwait.kt │ ├── RxCancellable.kt │ ├── RxChannel.kt │ ├── RxCompletable.kt │ ├── RxConvert.kt │ ├── RxFlowable.kt │ ├── RxMaybe.kt │ ├── RxObservable.kt │ ├── RxScheduler.kt │ ├── RxSingle.kt │ └── module-info.java │ └── test │ ├── BackpressureTest.kt │ ├── Check.kt │ ├── CompletableTest.kt │ ├── ConvertTest.kt │ ├── FlowAsFlowableTest.kt │ ├── FlowAsObservableTest.kt │ ├── FlowableContextTest.kt │ ├── FlowableExceptionHandlingTest.kt │ ├── FlowableTest.kt │ ├── IntegrationTest.kt │ ├── IterableFlowAsFlowableTckTest.kt │ ├── LeakedExceptionTest.kt │ ├── MaybeTest.kt │ ├── ObservableAsFlowTest.kt │ ├── ObservableCollectTest.kt │ ├── ObservableCompletionStressTest.kt │ ├── ObservableExceptionHandlingTest.kt │ ├── ObservableMultiTest.kt │ ├── ObservableSingleTest.kt │ ├── ObservableSourceAsFlowStressTest.kt │ ├── ObservableSubscriptionSelectTest.kt │ ├── ObservableTest.kt │ ├── SchedulerStressTest.kt │ ├── SchedulerTest.kt │ └── SingleTest.kt ├── settings.gradle.kts ├── site └── stdlib.package.list ├── test-utils ├── build.gradle.kts ├── common │ └── src │ │ ├── LaunchFlow.kt │ │ ├── MainDispatcherTestBase.kt │ │ └── TestBase.common.kt ├── js │ └── src │ │ └── TestBase.kt ├── jvm │ └── src │ │ ├── Exceptions.kt │ │ ├── ExecutorRule.kt │ │ ├── FieldWalker.kt │ │ ├── TestBase.kt │ │ └── Threads.kt ├── native │ └── src │ │ └── TestBase.kt ├── wasmJs │ └── src │ │ └── TestBase.kt └── wasmWasi │ └── src │ └── TestBase.kt └── ui ├── README.md ├── coroutines-guide-ui.md ├── knit.code.include ├── knit.properties ├── kotlinx-coroutines-android ├── README.md ├── android-unit-tests │ ├── build.gradle.kts │ ├── resources │ │ └── META-INF │ │ │ └── services │ │ │ └── kotlinx.coroutines.CoroutineScope │ ├── src │ │ └── EmptyCoroutineScopeImpl.kt │ └── test │ │ └── ordered │ │ └── tests │ │ ├── CustomizedRobolectricTest.kt │ │ ├── FirstMockedMainTest.kt │ │ ├── FirstRobolectricTest.kt │ │ ├── MockedMainTest.kt │ │ ├── RobolectricTest.kt │ │ └── TestComponent.kt ├── api │ └── kotlinx-coroutines-android.api ├── build.gradle.kts ├── package.list ├── resources │ └── META-INF │ │ ├── com.android.tools │ │ ├── proguard │ │ │ └── coroutines.pro │ │ ├── r8-from-1.6.0 │ │ │ └── coroutines.pro │ │ └── r8-upto-3.0.0 │ │ │ └── coroutines.pro │ │ ├── proguard │ │ └── coroutines.pro │ │ └── services │ │ ├── kotlinx.coroutines.CoroutineExceptionHandler │ │ └── kotlinx.coroutines.internal.MainDispatcherFactory ├── src │ ├── AndroidExceptionPreHandler.kt │ ├── HandlerDispatcher.kt │ └── module-info.java ├── test │ ├── AndroidExceptionPreHandlerTest.kt │ ├── DisabledHandlerTest.kt │ ├── HandlerDispatcherAsyncTest.kt │ ├── HandlerDispatcherTest.kt │ └── R8ServiceLoaderOptimizationTest.kt └── testdata │ ├── r8-test-common.pro │ ├── r8-test-rules-no-optim.pro │ └── r8-test-rules.pro ├── kotlinx-coroutines-javafx ├── README.md ├── api │ └── kotlinx-coroutines-javafx.api ├── build.gradle.kts ├── resources │ └── META-INF │ │ └── services │ │ └── kotlinx.coroutines.internal.MainDispatcherFactory ├── src │ ├── JavaFxConvert.kt │ ├── JavaFxDispatcher.kt │ └── module-info.java └── test │ ├── JavaFxDispatcherTest.kt │ ├── JavaFxObservableAsFlowTest.kt │ ├── JavaFxStressTest.kt │ ├── examples │ ├── FxAsFlow.kt │ └── FxExampleApp.kt │ └── guide │ ├── example-ui-actor-01.kt │ ├── example-ui-actor-02.kt │ ├── example-ui-actor-03.kt │ ├── example-ui-advanced-01.kt │ ├── example-ui-advanced-02.kt │ ├── example-ui-basic-01.kt │ ├── example-ui-basic-02.kt │ ├── example-ui-basic-03.kt │ ├── example-ui-blocking-01.kt │ ├── example-ui-blocking-02.kt │ └── example-ui-blocking-03.kt ├── kotlinx-coroutines-swing ├── README.md ├── api │ └── kotlinx-coroutines-swing.api ├── build.gradle.kts ├── resources │ └── META-INF │ │ └── services │ │ └── kotlinx.coroutines.internal.MainDispatcherFactory ├── src │ ├── SwingDispatcher.kt │ └── module-info.java └── test │ ├── SwingTest.kt │ └── examples │ └── SwingExampleApp.kt ├── ui-example-android.png └── ui-example-javafx.png /.github/ISSUE_TEMPLATE/bug_report.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/.github/ISSUE_TEMPLATE/bug_report.md -------------------------------------------------------------------------------- /.github/ISSUE_TEMPLATE/config.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/.github/ISSUE_TEMPLATE/config.yml -------------------------------------------------------------------------------- /.github/ISSUE_TEMPLATE/design_considerations.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/.github/ISSUE_TEMPLATE/design_considerations.md -------------------------------------------------------------------------------- /.github/ISSUE_TEMPLATE/feature_request.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/.github/ISSUE_TEMPLATE/feature_request.md -------------------------------------------------------------------------------- /.github/ISSUE_TEMPLATE/guide.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/.github/ISSUE_TEMPLATE/guide.md -------------------------------------------------------------------------------- /.github/ISSUE_TEMPLATE/rc_feedback.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/.github/ISSUE_TEMPLATE/rc_feedback.md -------------------------------------------------------------------------------- /.gitignore: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/.gitignore -------------------------------------------------------------------------------- /.idea/codeStyleSettings.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/.idea/codeStyleSettings.xml -------------------------------------------------------------------------------- /.idea/codeStyles/Project.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/.idea/codeStyles/Project.xml -------------------------------------------------------------------------------- /.idea/codeStyles/codeStyleConfig.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/.idea/codeStyles/codeStyleConfig.xml -------------------------------------------------------------------------------- /.idea/copyright/profiles_settings.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/.idea/copyright/profiles_settings.xml -------------------------------------------------------------------------------- /.idea/dictionaries/shared.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/.idea/dictionaries/shared.xml -------------------------------------------------------------------------------- /.idea/icon.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/.idea/icon.png -------------------------------------------------------------------------------- /.idea/vcs.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/.idea/vcs.xml -------------------------------------------------------------------------------- /CHANGES.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/CHANGES.md -------------------------------------------------------------------------------- /CHANGES_UP_TO_1.7.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/CHANGES_UP_TO_1.7.md -------------------------------------------------------------------------------- /CODE_OF_CONDUCT.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/CODE_OF_CONDUCT.md -------------------------------------------------------------------------------- /CONTRIBUTING.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/CONTRIBUTING.md -------------------------------------------------------------------------------- /LICENSE.txt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/LICENSE.txt -------------------------------------------------------------------------------- /README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/README.md -------------------------------------------------------------------------------- /RELEASE.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/RELEASE.md -------------------------------------------------------------------------------- /benchmarks/build.gradle.kts: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/benchmarks/build.gradle.kts -------------------------------------------------------------------------------- /benchmarks/scripts/generate_plots_flow_flatten_merge.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/benchmarks/scripts/generate_plots_flow_flatten_merge.py -------------------------------------------------------------------------------- /benchmarks/src/jmh/kotlin/benchmarks/ChannelSinkBenchmark.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/benchmarks/src/jmh/kotlin/benchmarks/ChannelSinkBenchmark.kt -------------------------------------------------------------------------------- /benchmarks/src/jmh/kotlin/benchmarks/flow/NumbersBenchmark.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/benchmarks/src/jmh/kotlin/benchmarks/flow/NumbersBenchmark.kt -------------------------------------------------------------------------------- /benchmarks/src/jmh/kotlin/benchmarks/flow/SafeFlowBenchmark.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/benchmarks/src/jmh/kotlin/benchmarks/flow/SafeFlowBenchmark.kt -------------------------------------------------------------------------------- /benchmarks/src/jmh/kotlin/benchmarks/flow/TakeBenchmark.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/benchmarks/src/jmh/kotlin/benchmarks/flow/TakeBenchmark.kt -------------------------------------------------------------------------------- /benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/README.md -------------------------------------------------------------------------------- /benchmarks/src/jmh/resources/ospd.txt.gz: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/benchmarks/src/jmh/resources/ospd.txt.gz -------------------------------------------------------------------------------- /benchmarks/src/jmh/resources/words.shakespeare.txt.gz: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/benchmarks/src/jmh/resources/words.shakespeare.txt.gz -------------------------------------------------------------------------------- /benchmarks/src/main/kotlin/benchmarks/common/BenchmarkUtils.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/benchmarks/src/main/kotlin/benchmarks/common/BenchmarkUtils.kt -------------------------------------------------------------------------------- /bump-version.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/bump-version.sh -------------------------------------------------------------------------------- /coroutines-guide.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/coroutines-guide.md -------------------------------------------------------------------------------- /docs/basics.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/basics.md -------------------------------------------------------------------------------- /docs/cancellation-and-timeouts.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/cancellation-and-timeouts.md -------------------------------------------------------------------------------- /docs/cfg/buildprofiles.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/cfg/buildprofiles.xml -------------------------------------------------------------------------------- /docs/channels.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/channels.md -------------------------------------------------------------------------------- /docs/compatibility.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/compatibility.md -------------------------------------------------------------------------------- /docs/composing-suspending-functions.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/composing-suspending-functions.md -------------------------------------------------------------------------------- /docs/coroutine-context-and-dispatchers.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/coroutine-context-and-dispatchers.md -------------------------------------------------------------------------------- /docs/coroutines-guide.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/coroutines-guide.md -------------------------------------------------------------------------------- /docs/debugging.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/debugging.md -------------------------------------------------------------------------------- /docs/exception-handling.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/exception-handling.md -------------------------------------------------------------------------------- /docs/flow.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/flow.md -------------------------------------------------------------------------------- /docs/images/after.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/after.png -------------------------------------------------------------------------------- /docs/images/before.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/before.png -------------------------------------------------------------------------------- /docs/images/coroutine-breakpoint.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutine-breakpoint.png -------------------------------------------------------------------------------- /docs/images/coroutine-debug-1.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutine-debug-1.png -------------------------------------------------------------------------------- /docs/images/coroutine-debug-2.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutine-debug-2.png -------------------------------------------------------------------------------- /docs/images/coroutine-debug-3.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutine-debug-3.png -------------------------------------------------------------------------------- /docs/images/coroutine-idea-debugging-1.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutine-idea-debugging-1.png -------------------------------------------------------------------------------- /docs/images/coroutines-and-channels/aggregate.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutines-and-channels/aggregate.png -------------------------------------------------------------------------------- /docs/images/coroutines-and-channels/background.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutines-and-channels/background.png -------------------------------------------------------------------------------- /docs/images/coroutines-and-channels/blocking.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutines-and-channels/blocking.png -------------------------------------------------------------------------------- /docs/images/coroutines-and-channels/buffered-channel.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutines-and-channels/buffered-channel.png -------------------------------------------------------------------------------- /docs/images/coroutines-and-channels/callbacks.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutines-and-channels/callbacks.png -------------------------------------------------------------------------------- /docs/images/coroutines-and-channels/concurrency.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutines-and-channels/concurrency.png -------------------------------------------------------------------------------- /docs/images/coroutines-and-channels/conflated-channel.gif: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutines-and-channels/conflated-channel.gif -------------------------------------------------------------------------------- /docs/images/coroutines-and-channels/generating-token.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutines-and-channels/generating-token.png -------------------------------------------------------------------------------- /docs/images/coroutines-and-channels/initial-window.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutines-and-channels/initial-window.png -------------------------------------------------------------------------------- /docs/images/coroutines-and-channels/loading.gif: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutines-and-channels/loading.gif -------------------------------------------------------------------------------- /docs/images/coroutines-and-channels/progress.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutines-and-channels/progress.png -------------------------------------------------------------------------------- /docs/images/coroutines-and-channels/rendezvous-channel.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutines-and-channels/rendezvous-channel.png -------------------------------------------------------------------------------- /docs/images/coroutines-and-channels/run-configuration.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutines-and-channels/run-configuration.png -------------------------------------------------------------------------------- /docs/images/coroutines-and-channels/suspend-requests.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutines-and-channels/suspend-requests.png -------------------------------------------------------------------------------- /docs/images/coroutines-and-channels/suspension-process.gif: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutines-and-channels/suspension-process.gif -------------------------------------------------------------------------------- /docs/images/coroutines-and-channels/time-comparison.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutines-and-channels/time-comparison.png -------------------------------------------------------------------------------- /docs/images/coroutines-and-channels/unlimited-channel.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutines-and-channels/unlimited-channel.png -------------------------------------------------------------------------------- /docs/images/coroutines-and-channels/using-channel.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutines-and-channels/using-channel.png -------------------------------------------------------------------------------- /docs/images/coroutines-and-threads.svg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/coroutines-and-threads.svg -------------------------------------------------------------------------------- /docs/images/flow-breakpoint.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/flow-breakpoint.png -------------------------------------------------------------------------------- /docs/images/flow-build-project.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/flow-build-project.png -------------------------------------------------------------------------------- /docs/images/flow-debug-1.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/flow-debug-1.png -------------------------------------------------------------------------------- /docs/images/flow-debug-2.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/flow-debug-2.png -------------------------------------------------------------------------------- /docs/images/flow-debug-3.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/flow-debug-3.png -------------------------------------------------------------------------------- /docs/images/flow-debug-4.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/flow-debug-4.png -------------------------------------------------------------------------------- /docs/images/flow-debug-project.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/flow-debug-project.png -------------------------------------------------------------------------------- /docs/images/flow-resume-debug.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/flow-resume-debug.png -------------------------------------------------------------------------------- /docs/images/new-gradle-project-jvm.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/new-gradle-project-jvm.png -------------------------------------------------------------------------------- /docs/images/parallelism-and-concurrency.svg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/parallelism-and-concurrency.svg -------------------------------------------------------------------------------- /docs/images/run-icon.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/run-icon.png -------------------------------------------------------------------------------- /docs/images/variable-optimised-out.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/images/variable-optimised-out.png -------------------------------------------------------------------------------- /docs/kc.tree: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/kc.tree -------------------------------------------------------------------------------- /docs/knit.code.include: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/knit.code.include -------------------------------------------------------------------------------- /docs/knit.test.template: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/knit.test.template -------------------------------------------------------------------------------- /docs/select-expression.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/select-expression.md -------------------------------------------------------------------------------- /docs/shared-mutable-state-and-concurrency.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/shared-mutable-state-and-concurrency.md -------------------------------------------------------------------------------- /docs/topics/cancellation-and-timeouts.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/topics/cancellation-and-timeouts.md -------------------------------------------------------------------------------- /docs/topics/channels.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/topics/channels.md -------------------------------------------------------------------------------- /docs/topics/compatibility.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/topics/compatibility.md -------------------------------------------------------------------------------- /docs/topics/composing-suspending-functions.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/topics/composing-suspending-functions.md -------------------------------------------------------------------------------- /docs/topics/coroutine-context-and-dispatchers.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/topics/coroutine-context-and-dispatchers.md -------------------------------------------------------------------------------- /docs/topics/coroutines-and-channels.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/topics/coroutines-and-channels.md -------------------------------------------------------------------------------- /docs/topics/coroutines-basics.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/topics/coroutines-basics.md -------------------------------------------------------------------------------- /docs/topics/coroutines-guide.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/topics/coroutines-guide.md -------------------------------------------------------------------------------- /docs/topics/debug-coroutines-with-idea.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/topics/debug-coroutines-with-idea.md -------------------------------------------------------------------------------- /docs/topics/debug-flow-with-idea.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/topics/debug-flow-with-idea.md -------------------------------------------------------------------------------- /docs/topics/debugging.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/topics/debugging.md -------------------------------------------------------------------------------- /docs/topics/exception-handling.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/topics/exception-handling.md -------------------------------------------------------------------------------- /docs/topics/flow.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/topics/flow.md -------------------------------------------------------------------------------- /docs/topics/knit.properties: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/topics/knit.properties -------------------------------------------------------------------------------- /docs/topics/select-expression.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/topics/select-expression.md -------------------------------------------------------------------------------- /docs/topics/shared-mutable-state-and-concurrency.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/topics/shared-mutable-state-and-concurrency.md -------------------------------------------------------------------------------- /docs/writerside.cfg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/docs/writerside.cfg -------------------------------------------------------------------------------- /dokka-templates/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/dokka-templates/README.md -------------------------------------------------------------------------------- /gradle.properties: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/gradle.properties -------------------------------------------------------------------------------- /gradle/wrapper/gradle-wrapper.jar: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/gradle/wrapper/gradle-wrapper.jar -------------------------------------------------------------------------------- /gradle/wrapper/gradle-wrapper.properties: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/gradle/wrapper/gradle-wrapper.properties -------------------------------------------------------------------------------- /gradlew: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/gradlew -------------------------------------------------------------------------------- /gradlew.bat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/gradlew.bat -------------------------------------------------------------------------------- /integration-testing/.gitignore: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration-testing/.gitignore -------------------------------------------------------------------------------- /integration-testing/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration-testing/README.md -------------------------------------------------------------------------------- /integration-testing/build.gradle.kts: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration-testing/build.gradle.kts -------------------------------------------------------------------------------- /integration-testing/gradle.properties: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration-testing/gradle.properties -------------------------------------------------------------------------------- /integration-testing/gradle/wrapper/gradle-wrapper.jar: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration-testing/gradle/wrapper/gradle-wrapper.jar -------------------------------------------------------------------------------- /integration-testing/gradle/wrapper/gradle-wrapper.properties: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration-testing/gradle/wrapper/gradle-wrapper.properties -------------------------------------------------------------------------------- /integration-testing/gradlew: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration-testing/gradlew -------------------------------------------------------------------------------- /integration-testing/gradlew.bat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration-testing/gradlew.bat -------------------------------------------------------------------------------- /integration-testing/java8Test/build.gradle.kts: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration-testing/java8Test/build.gradle.kts -------------------------------------------------------------------------------- /integration-testing/jpmsTest/build.gradle.kts: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration-testing/jpmsTest/build.gradle.kts -------------------------------------------------------------------------------- /integration-testing/settings.gradle.kts: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration-testing/settings.gradle.kts -------------------------------------------------------------------------------- /integration-testing/smokeTest/build.gradle.kts: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration-testing/smokeTest/build.gradle.kts -------------------------------------------------------------------------------- /integration-testing/smokeTest/src/commonMain/kotlin/Sample.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration-testing/smokeTest/src/commonMain/kotlin/Sample.kt -------------------------------------------------------------------------------- /integration-testing/src/coreAgentTest/kotlin/CoreAgentTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration-testing/src/coreAgentTest/kotlin/CoreAgentTest.kt -------------------------------------------------------------------------------- /integration-testing/src/debugAgentTest/kotlin/DebugAgentTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration-testing/src/debugAgentTest/kotlin/DebugAgentTest.kt -------------------------------------------------------------------------------- /integration-testing/src/debugAgentTest/kotlin/DebugProbes.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration-testing/src/debugAgentTest/kotlin/DebugProbes.kt -------------------------------------------------------------------------------- /integration/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration/README.md -------------------------------------------------------------------------------- /integration/kotlinx-coroutines-guava/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration/kotlinx-coroutines-guava/README.md -------------------------------------------------------------------------------- /integration/kotlinx-coroutines-guava/build.gradle.kts: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration/kotlinx-coroutines-guava/build.gradle.kts -------------------------------------------------------------------------------- /integration/kotlinx-coroutines-guava/package.list: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration/kotlinx-coroutines-guava/package.list -------------------------------------------------------------------------------- /integration/kotlinx-coroutines-guava/src/ListenableFuture.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration/kotlinx-coroutines-guava/src/ListenableFuture.kt -------------------------------------------------------------------------------- /integration/kotlinx-coroutines-guava/src/module-info.java: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration/kotlinx-coroutines-guava/src/module-info.java -------------------------------------------------------------------------------- /integration/kotlinx-coroutines-jdk8/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration/kotlinx-coroutines-jdk8/README.md -------------------------------------------------------------------------------- /integration/kotlinx-coroutines-jdk8/api/kotlinx-coroutines-jdk8.api: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /integration/kotlinx-coroutines-jdk8/build.gradle.kts: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /integration/kotlinx-coroutines-jdk8/src/module-info.java: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration/kotlinx-coroutines-jdk8/src/module-info.java -------------------------------------------------------------------------------- /integration/kotlinx-coroutines-play-services/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration/kotlinx-coroutines-play-services/README.md -------------------------------------------------------------------------------- /integration/kotlinx-coroutines-play-services/build.gradle.kts: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration/kotlinx-coroutines-play-services/build.gradle.kts -------------------------------------------------------------------------------- /integration/kotlinx-coroutines-play-services/package.list: -------------------------------------------------------------------------------- 1 | com.google.android.gms.tasks -------------------------------------------------------------------------------- /integration/kotlinx-coroutines-play-services/src/Tasks.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration/kotlinx-coroutines-play-services/src/Tasks.kt -------------------------------------------------------------------------------- /integration/kotlinx-coroutines-play-services/test/TaskTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration/kotlinx-coroutines-play-services/test/TaskTest.kt -------------------------------------------------------------------------------- /integration/kotlinx-coroutines-slf4j/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration/kotlinx-coroutines-slf4j/README.md -------------------------------------------------------------------------------- /integration/kotlinx-coroutines-slf4j/build.gradle.kts: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration/kotlinx-coroutines-slf4j/build.gradle.kts -------------------------------------------------------------------------------- /integration/kotlinx-coroutines-slf4j/package.list: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration/kotlinx-coroutines-slf4j/package.list -------------------------------------------------------------------------------- /integration/kotlinx-coroutines-slf4j/src/MDCContext.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration/kotlinx-coroutines-slf4j/src/MDCContext.kt -------------------------------------------------------------------------------- /integration/kotlinx-coroutines-slf4j/src/module-info.java: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration/kotlinx-coroutines-slf4j/src/module-info.java -------------------------------------------------------------------------------- /integration/kotlinx-coroutines-slf4j/test/MDCContextTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/integration/kotlinx-coroutines-slf4j/test/MDCContextTest.kt -------------------------------------------------------------------------------- /knit.properties: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/knit.properties -------------------------------------------------------------------------------- /kotlinx-coroutines-bom/build.gradle.kts: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-bom/build.gradle.kts -------------------------------------------------------------------------------- /kotlinx-coroutines-core/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/README.md -------------------------------------------------------------------------------- /kotlinx-coroutines-core/api/kotlinx-coroutines-core.api: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/api/kotlinx-coroutines-core.api -------------------------------------------------------------------------------- /kotlinx-coroutines-core/api/kotlinx-coroutines-core.klib.api: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/api/kotlinx-coroutines-core.klib.api -------------------------------------------------------------------------------- /kotlinx-coroutines-core/benchmarks/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/benchmarks/README.md -------------------------------------------------------------------------------- /kotlinx-coroutines-core/build.gradle.kts: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/build.gradle.kts -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/README.md -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/AbstractCoroutine.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/AbstractCoroutine.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/Annotations.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/Annotations.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/Await.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/Await.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/Builders.common.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/Builders.common.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/CancellableContinuation.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/CancellableContinuation.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/CompletableDeferred.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/CompletableDeferred.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/CompletableJob.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/CompletableJob.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/CompletionHandler.common.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/CompletionHandler.common.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/CompletionState.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/CompletionState.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/CoroutineContext.common.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/CoroutineContext.common.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/CoroutineDispatcher.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/CoroutineDispatcher.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/CoroutineExceptionHandler.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/CoroutineExceptionHandler.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/CoroutineName.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/CoroutineName.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/CoroutineScope.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/CoroutineScope.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/CoroutineStart.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/CoroutineStart.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/Debug.common.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/Debug.common.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/Deferred.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/Deferred.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/Delay.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/Delay.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/Dispatchers.common.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/Dispatchers.common.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/EventLoop.common.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/EventLoop.common.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/Exceptions.common.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/Exceptions.common.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/Guidance.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/Guidance.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/Job.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/Job.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/JobSupport.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/JobSupport.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/MainCoroutineDispatcher.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/MainCoroutineDispatcher.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/NonCancellable.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/NonCancellable.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/Runnable.common.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/Runnable.common.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/SchedulerTask.common.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/SchedulerTask.common.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/Supervisor.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/Supervisor.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/Timeout.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/Timeout.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/Unconfined.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/Unconfined.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/Waiter.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/Waiter.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/Yield.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/Yield.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/channels/Broadcast.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/channels/Broadcast.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/channels/BroadcastChannel.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/channels/BroadcastChannel.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/channels/BufferOverflow.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/channels/BufferOverflow.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/channels/BufferedChannel.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/channels/BufferedChannel.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/channels/Channel.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/channels/Channel.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/channels/ChannelCoroutine.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/channels/ChannelCoroutine.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/channels/Channels.common.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/channels/Channels.common.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/channels/Deprecated.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/channels/Deprecated.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/channels/Produce.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/channels/Produce.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/Builders.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/Builders.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/Channels.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/Channels.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/Flow.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/Flow.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/FlowCollector.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/FlowCollector.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/Migration.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/Migration.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/SharedFlow.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/SharedFlow.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/SharingStarted.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/SharingStarted.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/StateFlow.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/StateFlow.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/internal/ChannelFlow.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/internal/ChannelFlow.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/internal/Combine.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/internal/Combine.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/internal/Merge.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/internal/Merge.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/operators/Context.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/operators/Context.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/operators/Delay.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/operators/Delay.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/operators/Distinct.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/operators/Distinct.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/operators/Emitters.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/operators/Emitters.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/operators/Errors.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/operators/Errors.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/operators/Limit.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/operators/Limit.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/operators/Lint.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/operators/Lint.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/operators/Merge.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/operators/Merge.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/operators/Share.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/operators/Share.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/operators/Transform.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/operators/Transform.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/operators/Zip.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/operators/Zip.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/terminal/Collect.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/terminal/Collect.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/terminal/Count.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/terminal/Count.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/terminal/Logic.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/terminal/Logic.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/flow/terminal/Reduce.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/flow/terminal/Reduce.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/internal/DispatchedTask.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/internal/DispatchedTask.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/internal/InlineList.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/internal/InlineList.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/internal/Scopes.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/internal/Scopes.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/internal/Symbol.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/internal/Symbol.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/internal/ThreadSafeHeap.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/internal/ThreadSafeHeap.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/intrinsics/Cancellable.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/intrinsics/Cancellable.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/intrinsics/Undispatched.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/intrinsics/Undispatched.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/selects/OnTimeout.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/selects/OnTimeout.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/selects/Select.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/selects/Select.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/selects/SelectOld.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/selects/SelectOld.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/selects/SelectUnbiased.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/selects/SelectUnbiased.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/selects/WhileSelect.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/selects/WhileSelect.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/sync/Mutex.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/sync/Mutex.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/src/sync/Semaphore.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/src/sync/Semaphore.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/AbstractCoroutineTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/AbstractCoroutineTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/AsyncLazyTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/AsyncLazyTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/AsyncTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/AsyncTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/AwaitCancellationTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/AwaitCancellationTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/AwaitTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/AwaitTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/BuilderContractsTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/BuilderContractsTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/CancellableResumeTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/CancellableResumeTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/CompletableJobTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/CompletableJobTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/CoroutineScopeTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/CoroutineScopeTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/CoroutinesTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/CoroutinesTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/DelayDurationTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/DelayDurationTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/DelayTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/DelayTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/DurationToMillisTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/DurationToMillisTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/EmptyContext.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/EmptyContext.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/FailedJobTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/FailedJobTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/ImmediateYieldTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/ImmediateYieldTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/JobExtensionsTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/JobExtensionsTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/JobStatesTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/JobStatesTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/JobTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/JobTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/LaunchLazyTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/LaunchLazyTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/NonCancellableTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/NonCancellableTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/ParentCancellationTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/ParentCancellationTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/SupervisorTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/SupervisorTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/UnconfinedTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/UnconfinedTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/UndispatchedResultTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/UndispatchedResultTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/WithContextTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/WithContextTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/WithTimeoutOrNullTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/WithTimeoutOrNullTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/WithTimeoutTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/WithTimeoutTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/channels/BroadcastTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/channels/BroadcastTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/channels/ChannelsTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/channels/ChannelsTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/channels/ConsumeTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/channels/ConsumeTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/channels/ProduceTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/channels/ProduceTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/flow/BuildersTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/flow/BuildersTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/flow/IdFlowTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/flow/IdFlowTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/flow/NamedDispatchers.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/flow/NamedDispatchers.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/flow/SafeFlowTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/flow/SafeFlowTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/flow/VirtualTime.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/flow/VirtualTime.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/flow/operators/MapTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/flow/operators/MapTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/flow/operators/ZipTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/flow/operators/ZipTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/flow/terminal/FoldTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/flow/terminal/FoldTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/flow/terminal/LastTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/flow/terminal/LastTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/selects/SelectBiasTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/selects/SelectBiasTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/selects/SelectJobTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/selects/SelectJobTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/selects/SelectLoopTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/selects/SelectLoopTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/selects/SelectOldTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/selects/SelectOldTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/sync/MutexTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/sync/MutexTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/common/test/sync/SemaphoreTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/common/test/sync/SemaphoreTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/concurrent/src/Builders.concurrent.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/concurrent/src/Builders.concurrent.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/concurrent/src/Dispatchers.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/concurrent/src/Dispatchers.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/concurrent/src/channels/Channels.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/concurrent/src/channels/Channels.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/concurrent/test/RunBlockingTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/concurrent/test/RunBlockingTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/js/src/CoroutineContext.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/js/src/CoroutineContext.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/js/src/Debug.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/js/src/Debug.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/js/src/JSDispatcher.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/js/src/JSDispatcher.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/js/src/Promise.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/js/src/Promise.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/js/src/Window.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/js/src/Window.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/js/src/internal/CopyOnWriteList.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/js/src/internal/CopyOnWriteList.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/js/test/PromiseTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/js/test/PromiseTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jsAndWasmJsShared/src/EventLoop.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jsAndWasmJsShared/src/EventLoop.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jsAndWasmShared/src/Dispatchers.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jsAndWasmShared/src/Dispatchers.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jsAndWasmShared/src/Exceptions.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jsAndWasmShared/src/Exceptions.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jsAndWasmShared/src/Runnable.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jsAndWasmShared/src/Runnable.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jsAndWasmShared/src/SchedulerTask.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jsAndWasmShared/src/SchedulerTask.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/resources/DebugProbesKt.bin: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/resources/DebugProbesKt.bin -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/AbstractTimeSource.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/AbstractTimeSource.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/Builders.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/Builders.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/CoroutineContext.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/CoroutineContext.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/Debug.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/Debug.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/DebugStrings.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/DebugStrings.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/DefaultExecutor.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/DefaultExecutor.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/Dispatchers.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/Dispatchers.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/EventLoop.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/EventLoop.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/Exceptions.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/Exceptions.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/Executors.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/Executors.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/Future.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/Future.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/Interruptible.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/Interruptible.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/Runnable.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/Runnable.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/SchedulerTask.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/SchedulerTask.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/ThreadContextElement.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/ThreadContextElement.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/ThreadPoolDispatcher.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/ThreadPoolDispatcher.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/channels/Actor.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/channels/Actor.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/channels/TickerChannels.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/channels/TickerChannels.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/debug/CoroutineDebugging.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/debug/CoroutineDebugging.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/debug/internal/DebugProbes.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/debug/internal/DebugProbes.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/future/Future.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/future/Future.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/internal/Concurrent.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/internal/Concurrent.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/internal/FastServiceLoader.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/internal/FastServiceLoader.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/internal/LocalAtomics.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/internal/LocalAtomics.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/internal/MainDispatchers.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/internal/MainDispatchers.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/internal/ProbesSupport.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/internal/ProbesSupport.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/internal/Synchronized.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/internal/Synchronized.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/internal/SystemProps.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/internal/SystemProps.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/internal/ThreadContext.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/internal/ThreadContext.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/internal/ThreadLocal.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/internal/ThreadLocal.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/module-info.java: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/module-info.java -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/scheduling/Dispatcher.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/scheduling/Dispatcher.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/scheduling/Tasks.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/scheduling/Tasks.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/scheduling/WorkQueue.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/scheduling/WorkQueue.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/stream/Stream.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/stream/Stream.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/src/time/Time.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/src/time/Time.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/AbstractLincheckTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/AbstractLincheckTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/AsyncJvmTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/AsyncJvmTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/AwaitJvmTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/AwaitJvmTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/AwaitStressTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/AwaitStressTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/CancelledAwaitStressTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/CancelledAwaitStressTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/ConcurrentTestUtilities.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/ConcurrentTestUtilities.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/CoroutinesJvmTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/CoroutinesJvmTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/DebugThreadNameTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/DebugThreadNameTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/DefaultExecutorStressTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/DefaultExecutorStressTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/DelayJvmTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/DelayJvmTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/DispatcherKeyTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/DispatcherKeyTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/DispatchersToStringTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/DispatchersToStringTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/EventLoopsTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/EventLoopsTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/ExecutorsTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/ExecutorsTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/FailFastOnStartTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/FailFastOnStartTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/IODispatcherTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/IODispatcherTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/JobActivationStressTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/JobActivationStressTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/JobChildStressTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/JobChildStressTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/JobDisposeStressTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/JobDisposeStressTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/JobOnCompletionStressTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/JobOnCompletionStressTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/JobStressTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/JobStressTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/JoinStressTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/JoinStressTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/MemoryFootprintTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/MemoryFootprintTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/NoParamAssertionsTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/NoParamAssertionsTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/RejectedExecutionTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/RejectedExecutionTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/RunBlockingJvmTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/RunBlockingJvmTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/RunInterruptibleTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/RunInterruptibleTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/TestBaseTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/TestBaseTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/ThreadContextElementTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/ThreadContextElementTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/ThreadContextOrderTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/ThreadContextOrderTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/ThreadLocalStressTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/ThreadLocalStressTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/ThreadLocalTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/ThreadLocalTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/ThreadLocalsLeaksTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/ThreadLocalsLeaksTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/VirtualTimeSource.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/VirtualTimeSource.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/WithDefaultContextTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/WithDefaultContextTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/WithTimeoutOrNullJvmTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/WithTimeoutOrNullJvmTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/channels/ActorLazyTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/channels/ActorLazyTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/channels/ActorTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/channels/ActorTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/examples/example-delay-01.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/examples/example-delay-01.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/examples/example-delay-02.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/examples/example-delay-02.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/examples/example-delay-03.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/examples/example-delay-03.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/exceptions/Stacktraces.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/exceptions/Stacktraces.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/flow/CallbackFlowTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/flow/CallbackFlowTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/flow/FirstJvmTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/flow/FirstJvmTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/flow/FlatMapStressTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/flow/FlatMapStressTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/flow/SharedFlowStressTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/flow/SharedFlowStressTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/flow/SharingReferenceTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/flow/SharingReferenceTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/flow/SharingStressTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/flow/SharingStressTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/flow/StateFlowStressTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/flow/StateFlowStressTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-basic-01.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-basic-01.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-basic-02.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-basic-02.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-basic-03.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-basic-03.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-basic-04.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-basic-04.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-basic-05.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-basic-05.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-basic-06.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-basic-06.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-cancel-01.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-cancel-01.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-cancel-02.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-cancel-02.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-cancel-03.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-cancel-03.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-cancel-04.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-cancel-04.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-cancel-05.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-cancel-05.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-cancel-06.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-cancel-06.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-cancel-07.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-cancel-07.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-cancel-08.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-cancel-08.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-cancel-09.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-cancel-09.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-cancel-10.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-cancel-10.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-channel-01.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-channel-01.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-channel-02.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-channel-02.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-channel-03.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-channel-03.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-channel-04.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-channel-04.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-channel-05.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-channel-05.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-channel-06.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-channel-06.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-channel-07.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-channel-07.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-channel-08.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-channel-08.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-channel-09.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-channel-09.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-channel-10.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-channel-10.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-compose-01.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-compose-01.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-compose-02.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-compose-02.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-compose-03.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-compose-03.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-compose-04.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-compose-04.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-compose-05.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-compose-05.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-compose-06.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-compose-06.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-context-01.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-context-01.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-context-02.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-context-02.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-context-03.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-context-03.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-context-04.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-context-04.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-context-05.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-context-05.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-context-06.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-context-06.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-context-07.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-context-07.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-context-08.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-context-08.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-context-09.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-context-09.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-context-10.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-context-10.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-context-11.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-context-11.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-01.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-01.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-02.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-02.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-03.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-03.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-04.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-04.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-05.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-05.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-06.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-06.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-07.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-07.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-08.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-08.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-09.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-09.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-10.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-10.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-11.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-11.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-12.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-12.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-13.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-13.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-14.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-14.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-15.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-15.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-16.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-16.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-17.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-17.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-18.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-18.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-19.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-19.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-20.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-20.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-21.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-21.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-22.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-22.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-23.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-23.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-24.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-24.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-25.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-25.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-26.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-26.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-27.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-27.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-28.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-28.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-29.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-29.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-30.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-30.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-31.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-31.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-32.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-32.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-33.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-33.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-34.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-34.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-35.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-35.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-36.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-36.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-37.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-37.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-38.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-38.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-flow-39.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-flow-39.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-select-01.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-select-01.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-select-02.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-select-02.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-select-03.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-select-03.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-select-04.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-select-04.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-select-05.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-select-05.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-sync-01.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-sync-01.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-sync-02.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-sync-02.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-sync-03.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-sync-03.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-sync-04.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-sync-04.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-sync-05.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-sync-05.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-sync-06.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-sync-06.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/example-sync-07.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/example-sync-07.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/guide/test/FlowGuideTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/guide/test/FlowGuideTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/jdk8/future/AsFutureTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/jdk8/future/AsFutureTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/jdk8/future/FutureTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/jdk8/future/FutureTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/jdk8/time/FlowSampleTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/jdk8/time/FlowSampleTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/jdk8/time/WithTimeoutTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/jdk8/time/WithTimeoutTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/knit/TestUtil.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/knit/TestUtil.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/scheduling/TestTimeSource.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/scheduling/TestTimeSource.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/jvm/test/scheduling/WorkQueueTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/jvm/test/scheduling/WorkQueueTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/knit.properties: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/knit.properties -------------------------------------------------------------------------------- /kotlinx-coroutines-core/native/src/Builders.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/native/src/Builders.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/native/src/CoroutineContext.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/native/src/CoroutineContext.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/native/src/Debug.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/native/src/Debug.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/native/src/Dispatchers.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/native/src/Dispatchers.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/native/src/EventLoop.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/native/src/EventLoop.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/native/src/Exceptions.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/native/src/Exceptions.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/native/src/Runnable.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/native/src/Runnable.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/native/src/SchedulerTask.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/native/src/SchedulerTask.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/native/src/internal/Concurrent.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/native/src/internal/Concurrent.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/native/src/internal/LocalAtomics.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/native/src/internal/LocalAtomics.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/native/src/internal/ProbesSupport.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/native/src/internal/ProbesSupport.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/native/src/internal/Synchronized.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/native/src/internal/Synchronized.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/native/src/internal/SystemProps.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/native/src/internal/SystemProps.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/native/src/internal/ThreadContext.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/native/src/internal/ThreadContext.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/native/src/internal/ThreadLocal.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/native/src/internal/ThreadLocal.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/native/test/DelayExceptionTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/native/test/DelayExceptionTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/native/test/WorkerTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/native/test/WorkerTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/nativeDarwin/src/Dispatchers.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/nativeDarwin/src/Dispatchers.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/nativeDarwin/test/Launcher.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/nativeDarwin/test/Launcher.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/nativeOther/src/Dispatchers.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/nativeOther/src/Dispatchers.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/nativeOther/test/Launcher.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/nativeOther/test/Launcher.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/wasmJs/src/CoroutineContext.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/wasmJs/src/CoroutineContext.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/wasmJs/src/Debug.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/wasmJs/src/Debug.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/wasmJs/src/JSDispatcher.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/wasmJs/src/JSDispatcher.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/wasmJs/src/Promise.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/wasmJs/src/Promise.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/wasmJs/test/PromiseTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/wasmJs/test/PromiseTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/wasmWasi/src/Debug.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/wasmWasi/src/Debug.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-core/wasmWasi/src/EventLoop.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-core/wasmWasi/src/EventLoop.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/README.md -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/api/kotlinx-coroutines-debug.api: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/api/kotlinx-coroutines-debug.api -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/build.gradle.kts: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/build.gradle.kts -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/src/Attach.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/src/Attach.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/src/CoroutineInfo.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/src/CoroutineInfo.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/src/DebugProbes.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/src/DebugProbes.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/src/NoOpProbes.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/src/NoOpProbes.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/src/junit/CoroutinesTimeoutImpl.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/src/junit/CoroutinesTimeoutImpl.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/src/module-info.java: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/src/module-info.java -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/test/BlockHoundTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/test/BlockHoundTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/test/CoroutinesDumpTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/test/CoroutinesDumpTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/test/DebugLeaksTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/test/DebugLeaksTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/test/DebugProbesTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/test/DebugProbesTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/test/DebugTestBase.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/test/DebugTestBase.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/test/Example.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/test/Example.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/test/LazyCoroutineTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/test/LazyCoroutineTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/test/RecoveryExample.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/test/RecoveryExample.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/test/RunningThreadStackMergeTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/test/RunningThreadStackMergeTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/test/SanitizedProbesTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/test/SanitizedProbesTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/test/ScopedBuildersTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/test/ScopedBuildersTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/test/StacktraceUtils.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/test/StacktraceUtils.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/test/StandardBuildersDebugTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/test/StandardBuildersDebugTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/test/StartModeProbesTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/test/StartModeProbesTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/test/TestRuleExample.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/test/TestRuleExample.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/test/ToStringTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/test/ToStringTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/test/WithContextUndispatchedTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/test/WithContextUndispatchedTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/test/junit4/CoroutinesTimeoutTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/test/junit4/CoroutinesTimeoutTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/test/junit4/TestFailureValidation.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/test/junit4/TestFailureValidation.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/MIGRATION.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/MIGRATION.md -------------------------------------------------------------------------------- /kotlinx-coroutines-test/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/README.md -------------------------------------------------------------------------------- /kotlinx-coroutines-test/api/kotlinx-coroutines-test.api: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/api/kotlinx-coroutines-test.api -------------------------------------------------------------------------------- /kotlinx-coroutines-test/api/kotlinx-coroutines-test.klib.api: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/api/kotlinx-coroutines-test.klib.api -------------------------------------------------------------------------------- /kotlinx-coroutines-test/build.gradle.kts: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/build.gradle.kts -------------------------------------------------------------------------------- /kotlinx-coroutines-test/common/src/TestBuilders.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/common/src/TestBuilders.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/common/src/TestCoroutineScheduler.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/common/src/TestCoroutineScheduler.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/common/src/TestDispatcher.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/common/src/TestDispatcher.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/common/src/TestDispatchers.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/common/src/TestDispatchers.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/common/src/TestScope.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/common/src/TestScope.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/common/test/Helpers.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/common/test/Helpers.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/common/test/RunTestTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/common/test/RunTestTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/common/test/TestDispatchersTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/common/test/TestDispatchersTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/common/test/TestScopeTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/common/test/TestScopeTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/js/src/TestBuilders.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/js/src/TestBuilders.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/js/src/internal/TestMainDispatcher.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/js/src/internal/TestMainDispatcher.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/js/test/Helpers.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/js/test/Helpers.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/js/test/PromiseTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/js/test/PromiseTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/jvm/resources/META-INF/services/kotlinx.coroutines.internal.MainDispatcherFactory: -------------------------------------------------------------------------------- 1 | kotlinx.coroutines.test.internal.TestMainDispatcherFactory 2 | -------------------------------------------------------------------------------- /kotlinx-coroutines-test/jvm/src/TestBuildersJvm.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/jvm/src/TestBuildersJvm.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/jvm/src/module-info.java: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/jvm/src/module-info.java -------------------------------------------------------------------------------- /kotlinx-coroutines-test/jvm/test/DumpOnTimeoutTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/jvm/test/DumpOnTimeoutTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/jvm/test/HelpersJvm.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/jvm/test/HelpersJvm.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/jvm/test/MemoryLeakTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/jvm/test/MemoryLeakTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/jvm/test/MultithreadingTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/jvm/test/MultithreadingTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/jvm/test/RunTestStressTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/jvm/test/RunTestStressTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/jvm/test/UncaughtExceptionsTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/jvm/test/UncaughtExceptionsTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/native/src/TestBuilders.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/native/src/TestBuilders.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/native/test/Helpers.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/native/test/Helpers.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/npm/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/npm/README.md -------------------------------------------------------------------------------- /kotlinx-coroutines-test/npm/package.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/npm/package.json -------------------------------------------------------------------------------- /kotlinx-coroutines-test/wasmJs/src/TestBuilders.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/wasmJs/src/TestBuilders.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/wasmJs/test/Helpers.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/wasmJs/test/Helpers.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/wasmJs/test/PromiseTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/wasmJs/test/PromiseTest.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/wasmWasi/src/TestBuilders.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/wasmWasi/src/TestBuilders.kt -------------------------------------------------------------------------------- /kotlinx-coroutines-test/wasmWasi/test/Helpers.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/kotlinx-coroutines-test/wasmWasi/test/Helpers.kt -------------------------------------------------------------------------------- /license/NOTICE.txt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/license/NOTICE.txt -------------------------------------------------------------------------------- /reactive/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/README.md -------------------------------------------------------------------------------- /reactive/knit.properties: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/knit.properties -------------------------------------------------------------------------------- /reactive/knit.test.include: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/knit.test.include -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-jdk9/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-jdk9/README.md -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-jdk9/build.gradle.kts: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-jdk9/build.gradle.kts -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-jdk9/package.list: -------------------------------------------------------------------------------- 1 | java.util.concurrent.Flow 2 | -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-jdk9/src/Await.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-jdk9/src/Await.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-jdk9/src/Publish.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-jdk9/src/Publish.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-jdk9/src/ReactiveFlow.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-jdk9/src/ReactiveFlow.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-jdk9/src/module-info.java: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-jdk9/src/module-info.java -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-jdk9/test/AwaitTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-jdk9/test/AwaitTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-jdk9/test/FlowAsPublisherTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-jdk9/test/FlowAsPublisherTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-jdk9/test/IntegrationTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-jdk9/test/IntegrationTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-jdk9/test/PublishTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-jdk9/test/PublishTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-jdk9/test/PublisherAsFlowTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-jdk9/test/PublisherAsFlowTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-jdk9/test/PublisherCollectTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-jdk9/test/PublisherCollectTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-jdk9/test/PublisherMultiTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-jdk9/test/PublisherMultiTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactive/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactive/README.md -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactive/build.gradle.kts: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactive/build.gradle.kts -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactive/package.list: -------------------------------------------------------------------------------- 1 | org.reactivestreams 2 | -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactive/src/Await.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactive/src/Await.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactive/src/Channel.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactive/src/Channel.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactive/src/ContextInjector.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactive/src/ContextInjector.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactive/src/Convert.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactive/src/Convert.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactive/src/Migration.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactive/src/Migration.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactive/src/Publish.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactive/src/Publish.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactive/src/ReactiveFlow.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactive/src/ReactiveFlow.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactive/src/module-info.java: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactive/src/module-info.java -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactive/test/AwaitTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactive/test/AwaitTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactive/test/IntegrationTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactive/test/IntegrationTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactive/test/PublishTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactive/test/PublishTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactor/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactor/README.md -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactor/build.gradle.kts: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactor/build.gradle.kts -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactor/package.list: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactor/package.list -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactor/src/Convert.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactor/src/Convert.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactor/src/Flux.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactor/src/Flux.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactor/src/Migration.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactor/src/Migration.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactor/src/Mono.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactor/src/Mono.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactor/src/ReactorContext.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactor/src/ReactorContext.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactor/src/ReactorFlow.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactor/src/ReactorFlow.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactor/src/Scheduler.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactor/src/Scheduler.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactor/src/module-info.java: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactor/src/module-info.java -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactor/test/BackpressureTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactor/test/BackpressureTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactor/test/Check.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactor/test/Check.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactor/test/ConvertTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactor/test/ConvertTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactor/test/FlowAsFluxTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactor/test/FlowAsFluxTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactor/test/FluxContextTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactor/test/FluxContextTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactor/test/FluxMultiTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactor/test/FluxMultiTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactor/test/FluxSingleTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactor/test/FluxSingleTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactor/test/FluxTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactor/test/FluxTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactor/test/MonoTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactor/test/MonoTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-reactor/test/SchedulerTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-reactor/test/SchedulerTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/README.md -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/build.gradle.kts: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/build.gradle.kts -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/package.list: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/package.list -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/src/RxAwait.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/src/RxAwait.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/src/RxCancellable.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/src/RxCancellable.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/src/RxChannel.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/src/RxChannel.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/src/RxCompletable.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/src/RxCompletable.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/src/RxConvert.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/src/RxConvert.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/src/RxFlowable.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/src/RxFlowable.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/src/RxMaybe.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/src/RxMaybe.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/src/RxObservable.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/src/RxObservable.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/src/RxScheduler.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/src/RxScheduler.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/src/RxSingle.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/src/RxSingle.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/src/module-info.java: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/src/module-info.java -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/test/BackpressureTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/test/BackpressureTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/test/Check.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/test/Check.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/test/CompletableTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/test/CompletableTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/test/ConvertTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/test/ConvertTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/test/FlowAsFlowableTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/test/FlowAsFlowableTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/test/FlowAsObservableTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/test/FlowAsObservableTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/test/FlowableContextTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/test/FlowableContextTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/test/FlowableTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/test/FlowableTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/test/IntegrationTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/test/IntegrationTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/test/LeakedExceptionTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/test/LeakedExceptionTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/test/MaybeTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/test/MaybeTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/test/ObservableAsFlowTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/test/ObservableAsFlowTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/test/ObservableCollectTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/test/ObservableCollectTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/test/ObservableMultiTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/test/ObservableMultiTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/test/ObservableSingleTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/test/ObservableSingleTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/test/ObservableTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/test/ObservableTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/test/SchedulerStressTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/test/SchedulerStressTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/test/SchedulerTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/test/SchedulerTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx2/test/SingleTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx2/test/SingleTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/README.md -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/build.gradle.kts: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/build.gradle.kts -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/package.list: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/package.list -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/src/RxAwait.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/src/RxAwait.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/src/RxCancellable.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/src/RxCancellable.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/src/RxChannel.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/src/RxChannel.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/src/RxCompletable.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/src/RxCompletable.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/src/RxConvert.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/src/RxConvert.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/src/RxFlowable.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/src/RxFlowable.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/src/RxMaybe.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/src/RxMaybe.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/src/RxObservable.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/src/RxObservable.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/src/RxScheduler.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/src/RxScheduler.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/src/RxSingle.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/src/RxSingle.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/src/module-info.java: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/src/module-info.java -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/test/BackpressureTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/test/BackpressureTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/test/Check.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/test/Check.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/test/CompletableTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/test/CompletableTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/test/ConvertTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/test/ConvertTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/test/FlowAsFlowableTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/test/FlowAsFlowableTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/test/FlowAsObservableTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/test/FlowAsObservableTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/test/FlowableContextTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/test/FlowableContextTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/test/FlowableTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/test/FlowableTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/test/IntegrationTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/test/IntegrationTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/test/LeakedExceptionTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/test/LeakedExceptionTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/test/MaybeTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/test/MaybeTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/test/ObservableAsFlowTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/test/ObservableAsFlowTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/test/ObservableCollectTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/test/ObservableCollectTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/test/ObservableMultiTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/test/ObservableMultiTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/test/ObservableSingleTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/test/ObservableSingleTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/test/ObservableTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/test/ObservableTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/test/SchedulerStressTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/test/SchedulerStressTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/test/SchedulerTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/test/SchedulerTest.kt -------------------------------------------------------------------------------- /reactive/kotlinx-coroutines-rx3/test/SingleTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/reactive/kotlinx-coroutines-rx3/test/SingleTest.kt -------------------------------------------------------------------------------- /settings.gradle.kts: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/settings.gradle.kts -------------------------------------------------------------------------------- /site/stdlib.package.list: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/site/stdlib.package.list -------------------------------------------------------------------------------- /test-utils/build.gradle.kts: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/test-utils/build.gradle.kts -------------------------------------------------------------------------------- /test-utils/common/src/LaunchFlow.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/test-utils/common/src/LaunchFlow.kt -------------------------------------------------------------------------------- /test-utils/common/src/MainDispatcherTestBase.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/test-utils/common/src/MainDispatcherTestBase.kt -------------------------------------------------------------------------------- /test-utils/common/src/TestBase.common.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/test-utils/common/src/TestBase.common.kt -------------------------------------------------------------------------------- /test-utils/js/src/TestBase.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/test-utils/js/src/TestBase.kt -------------------------------------------------------------------------------- /test-utils/jvm/src/Exceptions.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/test-utils/jvm/src/Exceptions.kt -------------------------------------------------------------------------------- /test-utils/jvm/src/ExecutorRule.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/test-utils/jvm/src/ExecutorRule.kt -------------------------------------------------------------------------------- /test-utils/jvm/src/FieldWalker.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/test-utils/jvm/src/FieldWalker.kt -------------------------------------------------------------------------------- /test-utils/jvm/src/TestBase.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/test-utils/jvm/src/TestBase.kt -------------------------------------------------------------------------------- /test-utils/jvm/src/Threads.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/test-utils/jvm/src/Threads.kt -------------------------------------------------------------------------------- /test-utils/native/src/TestBase.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/test-utils/native/src/TestBase.kt -------------------------------------------------------------------------------- /test-utils/wasmJs/src/TestBase.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/test-utils/wasmJs/src/TestBase.kt -------------------------------------------------------------------------------- /test-utils/wasmWasi/src/TestBase.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/test-utils/wasmWasi/src/TestBase.kt -------------------------------------------------------------------------------- /ui/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/README.md -------------------------------------------------------------------------------- /ui/coroutines-guide-ui.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/coroutines-guide-ui.md -------------------------------------------------------------------------------- /ui/knit.code.include: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/knit.code.include -------------------------------------------------------------------------------- /ui/knit.properties: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/knit.properties -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-android/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-android/README.md -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-android/build.gradle.kts: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-android/build.gradle.kts -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-android/package.list: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-android/package.list -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-android/src/HandlerDispatcher.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-android/src/HandlerDispatcher.kt -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-android/src/module-info.java: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-android/src/module-info.java -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-android/test/DisabledHandlerTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-android/test/DisabledHandlerTest.kt -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-android/test/HandlerDispatcherTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-android/test/HandlerDispatcherTest.kt -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-android/testdata/r8-test-common.pro: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-android/testdata/r8-test-common.pro -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-android/testdata/r8-test-rules.pro: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-android/testdata/r8-test-rules.pro -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-javafx/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-javafx/README.md -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-javafx/build.gradle.kts: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-javafx/build.gradle.kts -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-javafx/resources/META-INF/services/kotlinx.coroutines.internal.MainDispatcherFactory: -------------------------------------------------------------------------------- 1 | kotlinx.coroutines.javafx.JavaFxDispatcherFactory 2 | -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-javafx/src/JavaFxConvert.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-javafx/src/JavaFxConvert.kt -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-javafx/src/JavaFxDispatcher.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-javafx/src/JavaFxDispatcher.kt -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-javafx/src/module-info.java: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-javafx/src/module-info.java -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-javafx/test/JavaFxDispatcherTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-javafx/test/JavaFxDispatcherTest.kt -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-javafx/test/JavaFxStressTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-javafx/test/JavaFxStressTest.kt -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-javafx/test/examples/FxAsFlow.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-javafx/test/examples/FxAsFlow.kt -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-javafx/test/examples/FxExampleApp.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-javafx/test/examples/FxExampleApp.kt -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-swing/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-swing/README.md -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-swing/api/kotlinx-coroutines-swing.api: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-swing/api/kotlinx-coroutines-swing.api -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-swing/build.gradle.kts: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-swing/build.gradle.kts -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-swing/src/SwingDispatcher.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-swing/src/SwingDispatcher.kt -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-swing/src/module-info.java: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-swing/src/module-info.java -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-swing/test/SwingTest.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-swing/test/SwingTest.kt -------------------------------------------------------------------------------- /ui/kotlinx-coroutines-swing/test/examples/SwingExampleApp.kt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/kotlinx-coroutines-swing/test/examples/SwingExampleApp.kt -------------------------------------------------------------------------------- /ui/ui-example-android.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/ui-example-android.png -------------------------------------------------------------------------------- /ui/ui-example-javafx.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/Kotlin/kotlinx.coroutines/HEAD/ui/ui-example-javafx.png --------------------------------------------------------------------------------