kotlinx-coroutines-android
kotlinx.coroutines.android
asCoroutineDispatcher()
awaitFrame()
HandlerDispatcher
kotlinx-coroutines-core
kotlinx.coroutines
asContextElement()
asCoroutineDispatcher()
asDeferred()
asExecutor()
asPromise()
async()
await()
awaitAll()
awaitAnimationFrame()
awaitCancellation()
cancel()
cancelAndJoin()
cancelChildren()
cancelFutureOnCancellation()
CancellableContinuation
CancellationException
CancellationException()
CloseableCoroutineDispatcher
CompletableDeferred
CompletableDeferred()
CompletableJob
completeWith()
CopyableThreadContextElement
CopyableThrowable
CoroutineDispatcher
CoroutineExceptionHandler
CoroutineExceptionHandler()
CoroutineName
CoroutineScope
coroutineScope()
CoroutineScope()
CoroutineStart
ATOMIC
DEFAULT
LAZY
UNDISPATCHED
currentCoroutineContext()
DEBUG_PROPERTY_NAME
DEBUG_PROPERTY_VALUE_AUTO
DEBUG_PROPERTY_VALUE_OFF
DEBUG_PROPERTY_VALUE_ON
Deferred
delay()
DelicateCoroutinesApi
Dispatchers
DisposableHandle
ensureActive()
ensurePresent()
ExecutorCoroutineDispatcher
ExperimentalCoroutinesApi
FlowPreview
GlobalScope
handleCoroutineException()
InternalCoroutinesApi
invoke()
IO_PARALLELISM_PROPERTY_NAME
isActive()
isPresent()
Job
job
Job()
joinAll()
launch()
MainCoroutineDispatcher
MainScope()
newCoroutineContext()
newFixedThreadPoolContext()
newSingleThreadContext()
NonCancellable
ObsoleteCoroutinesApi
plus()
promise()
runBlocking()
runInterruptible()
Runnable
Runnable()
SupervisorJob()
supervisorScope()
suspendCancellableCoroutine()
ThreadContextElement
TimeoutCancellationException
withContext()
withTimeout()
withTimeoutOrNull()
yield()
kotlinx.coroutines.channels
actor()
ActorScope
awaitClose()
broadcast()
BroadcastChannel
BroadcastChannel()
BufferOverflow
DROP_LATEST
DROP_OLDEST
SUSPEND
Channel
Channel()
ChannelIterator
ChannelResult
ClosedReceiveChannelException
ClosedSendChannelException
ConflatedBroadcastChannel
consume()
consumeEach()
getOrElse()
onClosed()
onFailure()
onReceiveOrNull()
onSuccess()
produce()
ProducerScope
ReceiveChannel
SendChannel
ticker()
TickerMode
FIXED_DELAY
FIXED_PERIOD
toList()
trySendBlocking()
kotlinx.coroutines.flow
AbstractFlow
asFlow()
asSharedFlow()
asStateFlow()
buffer()
callbackFlow()
cancellable()
catch()
channelFlow()
collect()
collectIndexed()
collectLatest()
combine()
combineTransform()
conflate()
consumeAsFlow()
count()
debounce()
DEFAULT_CONCURRENCY
DEFAULT_CONCURRENCY_PROPERTY_NAME
distinctUntilChanged()
distinctUntilChangedBy()
drop()
dropWhile()
emitAll()
emptyFlow()
filter()
filterIsInstance()
filterNot()
filterNotNull()
first()
firstOrNull()
flatMapConcat()
flatMapLatest()
flatMapMerge()
flattenConcat()
flattenMerge()
Flow
flow()
FlowCollector
flowOf()
flowOn()
fold()
getAndUpdate()
last()
lastOrNull()
launchIn()
map()
mapLatest()
mapNotNull()
merge()
MutableSharedFlow
MutableSharedFlow()
MutableStateFlow
MutableStateFlow()
onCompletion()
onEach()
onEmpty()
onStart()
onSubscription()
produceIn()
receiveAsFlow()
reduce()
retry()
retryWhen()
runningFold()
runningReduce()
sample()
scan()
SharedFlow
shareIn()
SharingCommand
START
STOP
STOP_AND_RESET_REPLAY_CACHE
SharingStarted
single()
singleOrNull()
StateFlow
stateIn()
take()
takeWhile()
toCollection()
toList()
toSet()
transform()
transformLatest()
transformWhile()
update()
updateAndGet()
WhileSubscribed()
withIndex()
zip()
kotlinx.coroutines.intrinsics
startCoroutineCancellable()
kotlinx.coroutines.selects
onTimeout()
select()
SelectBuilder
SelectClause0
SelectClause1
SelectClause2
selectUnbiased()
whileSelect()
kotlinx.coroutines.sync
Mutex
Mutex()
Semaphore
Semaphore()
withLock()
withPermit()
kotlinx-coroutines-debug
kotlinx.coroutines.debug
CoroutineInfo
CoroutinesBlockHoundIntegration
DebugProbes
State
CREATED
RUNNING
SUSPENDED
kotlinx.coroutines.debug.junit4
CoroutinesTimeout
kotlinx.coroutines.debug.junit5
CoroutinesTimeout
kotlinx-coroutines-guava
kotlinx.coroutines.guava
asDeferred()
asListenableFuture()
await()
future()
kotlinx-coroutines-javafx
kotlinx.coroutines.javafx
asFlow()
awaitPulse()
JavaFx
JavaFxDispatcher
kotlinx-coroutines-jdk8
kotlinx.coroutines.future
asCompletableFuture()
asDeferred()
await()
future()
kotlinx.coroutines.stream
consumeAsFlow()
kotlinx.coroutines.time
debounce()
delay()
onTimeout()
sample()
withTimeout()
withTimeoutOrNull()
kotlinx-coroutines-jdk9
kotlinx.coroutines.jdk9
asFlow()
asPublisher()
awaitFirst()
awaitFirstOrDefault()
awaitFirstOrElse()
awaitFirstOrNull()
awaitLast()
awaitSingle()
collect()
flowPublish()
kotlinx-coroutines-play-services
kotlinx.coroutines.tasks
asDeferred()
asTask()
await()
kotlinx-coroutines-reactive
kotlinx.coroutines.reactive
asFlow()
asPublisher()
awaitFirst()
awaitFirstOrDefault()
awaitFirstOrElse()
awaitFirstOrNull()
awaitLast()
awaitSingle()
collect()
publish()
kotlinx-coroutines-reactor
kotlinx.coroutines.reactor
asCoroutineContext()
asCoroutineDispatcher()
asFlux()
asMono()
awaitSingle()
awaitSingleOrNull()
flux()
mono()
ReactorContext
SchedulerCoroutineDispatcher
kotlinx-coroutines-rx2
kotlinx.coroutines.rx2
asCompletable()
asCoroutineDispatcher()
asFlow()
asFlowable()
asMaybe()
asObservable()
asSingle()
await()
awaitFirst()
awaitFirstOrDefault()
awaitFirstOrElse()
awaitFirstOrNull()
awaitLast()
awaitSingle()
awaitSingleOrNull()
collect()
rxCompletable()
rxFlowable()
rxMaybe()
rxObservable()
rxSingle()
SchedulerCoroutineDispatcher
kotlinx-coroutines-rx3
kotlinx.coroutines.rx3
asCompletable()
asCoroutineDispatcher()
asFlow()
asFlowable()
asMaybe()
asObservable()
asSingle()
await()
awaitFirst()
awaitFirstOrDefault()
awaitFirstOrElse()
awaitFirstOrNull()
awaitLast()
awaitSingle()
awaitSingleOrNull()
collect()
rxCompletable()
rxFlowable()
rxMaybe()
rxObservable()
rxSingle()
SchedulerCoroutineDispatcher
kotlinx-coroutines-slf4j
kotlinx.coroutines.slf4j
MDCContext
kotlinx-coroutines-swing
kotlinx.coroutines.swing
Swing
SwingDispatcher
kotlinx-coroutines-test
kotlinx.coroutines.test
advanceTimeBy()
advanceUntilIdle()
createTestCoroutineScope()
currentTime()
DelayController
pauseDispatcher()
resetMain()
resumeDispatcher()
runBlockingTest()
runBlockingTestOnTestScope()
runCurrent()
runTest()
runTestWithLegacyScope()
setMain()
StandardTestDispatcher()
TestCoroutineDispatcher
TestCoroutineExceptionHandler
TestCoroutineScheduler
TestCoroutineScope
TestCoroutineScope()
TestDispatcher
TestResult
TestScope
TestScope()
testTimeSource
UncaughtExceptionCaptor
uncaughtExceptions
UnconfinedTestDispatcher()