- AbstractChannel<E> - Class in kotlinx.coroutines.experimental.channels
- 
Abstract send/receive channel. It is a base class for all channel implementations. 
- AbstractChannel() - Constructor for class kotlinx.coroutines.experimental.channels.AbstractChannel
- 
Abstract send/receive channel. It is a base class for all channel implementations. 
- AbstractChannelKt - Class in kotlinx.coroutines.experimental.channels
-  
- AbstractContinuationKt - Class in kotlinx.coroutines.experimental
-  
- AbstractSendChannel<E> - Class in kotlinx.coroutines.experimental.channels
- 
Abstract send channel. It is a base class for all send channel implementations. 
- AbstractSendChannel() - Constructor for class kotlinx.coroutines.experimental.channels.AbstractSendChannel
- 
Abstract send channel. It is a base class for all send channel implementations. 
- actor(context, capacity, start, block) - Static method in class kotlinx.coroutines.experimental.channels.ActorKt
- 
Launches new coroutine that is receiving messages from its mailbox channel
and returns a reference to the coroutine as an  interface ActorJob. The resulting
object can be used to send messages to this coroutine. 
- ActorJob<E> - Interface in kotlinx.coroutines.experimental.channels
- 
Return type for actor coroutine builder. 
- ActorKt - Class in kotlinx.coroutines.experimental.channels
-  
- ActorScope<E> - Interface in kotlinx.coroutines.experimental.channels
- 
Scope for actor coroutine builder. 
- afterClose(cause) - Method in class kotlinx.coroutines.experimental.channels.AbstractSendChannel
- 
Invoked after successful close. 
- ArrayBroadcastChannel<E> - Class in kotlinx.coroutines.experimental.channels
- 
Broadcast channel with array buffer of a fixed capacity.
Sender suspends only when buffer is full due to one of the receives being slow to consume and
receiver suspends only when buffer is empty. 
- ArrayBroadcastChannel(capacity) - Constructor for class kotlinx.coroutines.experimental.channels.ArrayBroadcastChannel
- 
Broadcast channel with array buffer of a fixed capacity.
Sender suspends only when buffer is full due to one of the receives being slow to consume and
receiver suspends only when buffer is empty. 
- ArrayChannel<E> - Class in kotlinx.coroutines.experimental.channels
- 
Channel with array buffer of a fixed capacity.
Sender suspends only when buffer is fully and receiver suspends only when buffer is empty. 
- ArrayChannel(capacity) - Constructor for class kotlinx.coroutines.experimental.channels.ArrayChannel
- 
Channel with array buffer of a fixed capacity.
Sender suspends only when buffer is fully and receiver suspends only when buffer is empty. 
- asCoroutineDispatcher($receiver) - Static method in class kotlinx.coroutines.experimental.ExecutorsKt
- 
- async(context, start, block) - Static method in class kotlinx.coroutines.experimental.DeferredKt
- 
Creates new coroutine and returns its future result as an implementation of  interface Deferred. 
- attachChild(child) - Method in interface kotlinx.coroutines.experimental.Job
- 
Attaches child job so that this job becomes its parent and
returns a handle that should be used to detach it. 
- attachChild(child) - Method in class kotlinx.coroutines.experimental.NonCancellable
- 
- await($continuation) - Method in interface kotlinx.coroutines.experimental.Deferred
- 
Awaits for completion of this value without blocking a thread and resumes when deferred computation is complete,
returning the resulting value or throwing the corresponding exception if the deferred had completed exceptionally. 
- cancel(cause) - Method in interface kotlinx.coroutines.experimental.Job
- 
Cancels this job with an optional cancellation cause. The result is  true if this job was
cancelled as a result of this invocation and  false otherwise
(if it was already  completed or if it is  class NonCancellable).
Repeated invocations of this function have no effect and always produce  false. 
- cancel($receiver, cause) - Static method in class kotlinx.coroutines.experimental.JobKt
- 
Cancels  interface Job of this context with an optional cancellation cause. The result is  true if the job was
cancelled as a result of this invocation and  false if there is no job in the context or if it was already
cancelled or completed. See Job.cancel for details. 
- cancel(cause) - Method in class kotlinx.coroutines.experimental.NonCancellable
- 
Always returns false.
 
- cancelAndJoin($receiver, $continuation) - Static method in class kotlinx.coroutines.experimental.JobKt
- 
Cancels the job and suspends invoking coroutine until the cancelled job is complete. 
- cancelChildren(cause) - Method in interface kotlinx.coroutines.experimental.Job
- 
Cancels all  Job.attachChild jobs of this coroutine with the given cause. Unlike cancel,
the state of this job itself is not affected. 
- cancelChildren($receiver, cause) - Static method in class kotlinx.coroutines.experimental.JobKt
- 
Cancels all children of the  interface Job in this context with an optional cancellation cause.
It does not do anything if there is no job in the context or it has no children.
See Job.cancelChildren for details. 
- cancelChildren(cause) - Method in class kotlinx.coroutines.experimental.NonCancellable
- 
Does not do anything. 
- cancelFutureOnCompletion($receiver, future) - Static method in class kotlinx.coroutines.experimental.JobKt
- 
Cancels a specified future when this job is complete. 
- CancellableContinuation<T> - Interface in kotlinx.coroutines.experimental
- 
Cancellable continuation. Its job is completed when it is resumed or cancelled.
When cancel function is explicitly invoked, this continuation immediately resumes with CancellationException or
with the specified cancel cause. 
- CancellableContinuationKt - Class in kotlinx.coroutines.experimental
-  
- CancellableKt - Class in kotlinx.coroutines.experimental
-  
- Channel<E> - Interface in kotlinx.coroutines.experimental.channels
- 
- Channel() - Static method in class kotlinx.coroutines.experimental.channels.ChannelKt
- 
- Channel(capacity) - Static method in class kotlinx.coroutines.experimental.channels.ChannelKt
- 
Creates a channel with the specified buffer capacity (or without a buffer by default). 
- Channel.Factory - Class in kotlinx.coroutines.experimental.channels
- 
Constants for channel factory function Channel().
 
- ChannelIterator<E> - Interface in kotlinx.coroutines.experimental.channels
- 
Iterator for  interface ReceiveChannel. Instances of this interface are  not thread-safe and shall not be used
from concurrent coroutines. 
- ChannelKt - Class in kotlinx.coroutines.experimental.channels
-  
- ChannelsKt - Class in kotlinx.coroutines.experimental.channels
-  
- close(cause) - Method in class kotlinx.coroutines.experimental.channels.AbstractSendChannel
- 
Closes this channel with an optional exceptional cause.
This is an idempotent operation -- repeated invocations of this function have no effect and return  false.
Conceptually, its sends a special "close token" over this channel. Immediately after invocation of this function
isClosedForSend starts returning  true. However, isClosedForReceive
on the side of  interface ReceiveChannel starts returning  true only after all previously sent elements
are received. 
- close(cause) - Method in class kotlinx.coroutines.experimental.channels.ArrayBroadcastChannel
- 
Closes this channel with an optional exceptional cause.
This is an idempotent operation -- repeated invocations of this function have no effect and return  false.
Conceptually, its sends a special "close token" over this channel. Immediately after invocation of this function
isClosedForSend starts returning  true. However, isClosedForReceive
on the side of  interface ReceiveChannel starts returning  true only after all previously sent elements
are received. 
- close(cause) - Method in class kotlinx.coroutines.experimental.channels.ConflatedBroadcastChannel
- 
Closes this channel with an optional exceptional cause.
This is an idempotent operation -- repeated invocations of this function have no effect and return  false.
Conceptually, its sends a special "close token" over this channel. Immediately after invocation of this function
isClosedForSend starts returning  true. However, isClosedForReceive
on the side of  interface ReceiveChannel starts returning  true only after all previously sent elements
are received. 
- close(cause) - Method in interface kotlinx.coroutines.experimental.channels.SendChannel
- 
Closes this channel with an optional exceptional cause.
This is an idempotent operation -- repeated invocations of this function have no effect and return  false.
Conceptually, its sends a special "close token" over this channel. Immediately after invocation of this function
isClosedForSend starts returning  true. However, isClosedForReceive
on the side of  interface ReceiveChannel starts returning  true only after all previously sent elements
are received. 
- close() - Method in interface kotlinx.coroutines.experimental.channels.SubscriptionReceiveChannel
- 
Closes this subscription. 
- CLOSED - Static variable in class kotlinx.coroutines.experimental.channels.ConflatedBroadcastChannel
-  
- ClosedReceiveChannelException - Exception in kotlinx.coroutines.experimental.channels
- 
Indicates attempt to receive on isClosedForReceive
channel that was closed without a cause. A failed channel rethrows the original close cause
exception on receive attempts. 
- ClosedReceiveChannelException(message) - Constructor for exception kotlinx.coroutines.experimental.channels.ClosedReceiveChannelException
- 
Indicates attempt to receive on isClosedForReceive
channel that was closed without a cause. A failed channel rethrows the original close cause
exception on receive attempts. 
- ClosedSendChannelException - Exception in kotlinx.coroutines.experimental.channels
- 
Indicates attempt to send on isClosedForSend channel
that was closed without a cause. A failed channel rethrows the original close cause
exception on send attempts. 
- ClosedSendChannelException(message) - Constructor for exception kotlinx.coroutines.experimental.channels.ClosedSendChannelException
- 
Indicates attempt to send on isClosedForSend channel
that was closed without a cause. A failed channel rethrows the original close cause
exception on send attempts. 
- CommonPool - Class in kotlinx.coroutines.experimental
- 
Represents common pool of shared threads as coroutine dispatcher for compute-intensive tasks.
It uses  java.util.concurrent.ForkJoinPool when available, which implements efficient work-stealing algorithm for its queues, so every
coroutine resumption is dispatched as a separate task even when it already executes inside the pool.
When available, it wraps  ForkJoinPool.commonPool and provides a similar shared pool where not. 
- Companion - Static variable in class kotlinx.coroutines.experimental.channels.ConflatedBroadcastChannel
-  
- CompletableDeferred<T> - Interface in kotlinx.coroutines.experimental
- 
A  interface Deferred that can be completed via public functions
complete, completeExceptionally, and cancel. 
- CompletableDeferred() - Static method in class kotlinx.coroutines.experimental.CompletableDeferredKt
- 
- CompletableDeferred(value) - Static method in class kotlinx.coroutines.experimental.CompletableDeferredKt
- 
- CompletableDeferredKt - Class in kotlinx.coroutines.experimental
-  
- complete(value) - Method in interface kotlinx.coroutines.experimental.CompletableDeferred
- 
Completes this deferred value with a given value. The result is trueif this deferred was
completed as a result of this invocation andfalseotherwise (if it was already completed).
 
- completeExceptionally(exception) - Method in interface kotlinx.coroutines.experimental.CompletableDeferred
- 
Completes this deferred value exceptionally with a given exception. The result is trueif this deferred was
completed as a result of this invocation andfalseotherwise (if it was already completed).
 
- CompletionHandlerException - Exception in kotlinx.coroutines.experimental
- 
This exception gets thrown if an exception is caught while processing CompletionHandler invocation for  interface Job. 
- CompletionHandlerException(message, cause) - Constructor for exception kotlinx.coroutines.experimental.CompletionHandlerException
- 
This exception gets thrown if an exception is caught while processing CompletionHandler invocation for  interface Job. 
- component1() - Method in class kotlinx.coroutines.experimental.CoroutineName
- 
User-defined coroutine name. 
- CONFLATED - Static variable in interface kotlinx.coroutines.experimental.channels.Channel
- 
- CONFLATED - Static variable in class kotlinx.coroutines.experimental.channels.Channel.Factory
- 
- ConflatedBroadcastChannel<E> - Class in kotlinx.coroutines.experimental.channels
- 
- ConflatedBroadcastChannel() - Constructor for class kotlinx.coroutines.experimental.channels.ConflatedBroadcastChannel
- 
- ConflatedBroadcastChannel(value) - Constructor for class kotlinx.coroutines.experimental.channels.ConflatedBroadcastChannel
- 
Creates an instance of this class that already holds a value. 
- ConflatedChannel<E> - Class in kotlinx.coroutines.experimental.channels
- 
Channel that buffers at most one element and conflates all subsequent sendandofferinvocations,
so that the receiver always gets the most recently sent element.
Back-to-send sent elements are conflated -- only the the most recently sent element is received,
while previously sent elements are lost.
Sender to this channel never suspends and offer always returnstrue.
 
- ConflatedChannel() - Constructor for class kotlinx.coroutines.experimental.channels.ConflatedChannel
- 
Channel that buffers at most one element and conflates all subsequent sendandofferinvocations,
so that the receiver always gets the most recently sent element.
Back-to-send sent elements are conflated -- only the the most recently sent element is received,
while previously sent elements are lost.
Sender to this channel never suspends and offer always returnstrue.
 
- consumeEach($receiver, action, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
- 
Performs the given action for each received element. 
- consumeEach($receiver, action, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
- 
- copy(name) - Method in class kotlinx.coroutines.experimental.CoroutineName
- 
User-specified name of coroutine. This name is used in debugging mode.
See newCoroutineContext for the description of coroutine debugging facilities. 
- CoroutineContextKt - Class in kotlinx.coroutines.experimental
-  
- CoroutineDispatcher - Class in kotlinx.coroutines.experimental
- 
Base class that shall be extended by all coroutine dispatcher implementations. 
- CoroutineDispatcher() - Constructor for class kotlinx.coroutines.experimental.CoroutineDispatcher
- 
Base class that shall be extended by all coroutine dispatcher implementations. 
- CoroutineDispatcherKt - Class in kotlinx.coroutines.experimental
-  
- CoroutineExceptionHandler - Interface in kotlinx.coroutines.experimental
- 
An optional element on the coroutine context to handle uncaught exceptions. 
- CoroutineExceptionHandler(handler) - Static method in class kotlinx.coroutines.experimental.CoroutineExceptionHandlerKt
- 
- CoroutineExceptionHandler.Key - Class in kotlinx.coroutines.experimental
- 
- CoroutineExceptionHandlerKt - Class in kotlinx.coroutines.experimental
-  
- CoroutineName - Class in kotlinx.coroutines.experimental
- 
User-specified name of coroutine. This name is used in debugging mode.
See newCoroutineContext for the description of coroutine debugging facilities. 
- CoroutineName(name) - Constructor for class kotlinx.coroutines.experimental.CoroutineName
- 
User-specified name of coroutine. This name is used in debugging mode.
See newCoroutineContext for the description of coroutine debugging facilities. 
- CoroutineName.Key - Class in kotlinx.coroutines.experimental
- 
- CoroutineScope - Interface in kotlinx.coroutines.experimental
- 
Receiver interface for generic coroutine builders, so that the code inside coroutine has a convenient access
to its coroutineContext and its cancellation status via isActive. 
- CoroutineScope.DefaultImpls - Class in kotlinx.coroutines.experimental
- 
Receiver interface for generic coroutine builders, so that the code inside coroutine has a convenient access
to its coroutineContext and its cancellation status via isActive. 
- CoroutineStart - Enum in kotlinx.coroutines.experimental
- 
Defines start option for coroutines builders.
It is used in startparameter of launch, async, and actor
coroutine builder functions.
 
- CoroutineStart() - Constructor for enum kotlinx.coroutines.experimental.CoroutineStart
- 
Defines start option for coroutines builders.
It is used in startparameter of launch, async, and actor
coroutine builder functions.
 
- get($this, key) - Static method in class kotlinx.coroutines.experimental.Deferred.DefaultImpls
-  
- get($this, key) - Static method in class kotlinx.coroutines.experimental.Job.DefaultImpls
-  
- getCancellationException() - Method in interface kotlinx.coroutines.experimental.Job
- 
Returns CancellationException that signals the completion of this job. 
- getCancellationException() - Method in class kotlinx.coroutines.experimental.NonCancellable
- 
- getCapacity() - Method in class kotlinx.coroutines.experimental.channels.ArrayBroadcastChannel
- 
Buffer capacity. 
- getCapacity() - Method in class kotlinx.coroutines.experimental.channels.ArrayChannel
- 
Buffer capacity. 
- getChannel() - Method in interface kotlinx.coroutines.experimental.channels.ActorJob
- 
A reference to the mailbox channel that this coroutine is receiving messages from.
All the  interface SendChannel functions on this interface delegate to
the channel instance returned by this function. 
- getChannel() - Method in interface kotlinx.coroutines.experimental.channels.ActorScope
- 
A reference to the mailbox channel that this coroutine receives messages from.
It is provided for convenience, so that the code in the coroutine can refer
to the channel as  channel as apposed to  this.
All the  interface ReceiveChannel functions on this interface delegate to
the channel instance returned by this function. 
- getChannel() - Method in interface kotlinx.coroutines.experimental.channels.ProducerJob
- 
A reference to the channel that this coroutine is producing.
All the  interface ReceiveChannel functions on this interface delegate to
the channel instance returned by this function. 
- getChannel() - Method in interface kotlinx.coroutines.experimental.channels.ProducerScope
- 
A reference to the channel that this coroutine sends elements to.
It is provided for convenience, so that the code in the coroutine can refer
to the channel as  channel as apposed to  this.
All the  interface SendChannel functions on this interface delegate to
the channel instance returned by this function. 
- getCompleted() - Method in interface kotlinx.coroutines.experimental.Deferred
- 
Returns  completed result or throws  IllegalStateException if this deferred value has not
completed yet. It throws the corresponding exception if this deferred has
completed exceptionally. 
- getCompletionException($this) - Static method in class kotlinx.coroutines.experimental.Deferred.DefaultImpls
- 
Deprecated.  
- getCompletionExceptionOrNull() - Method in interface kotlinx.coroutines.experimental.Deferred
- 
Returns  completion exception result if this deferred completed exceptionally,
 null if it is completed normally, or throws  IllegalStateException if this deferred value has not
completed yet. 
- getCoroutineContext($this) - Static method in class kotlinx.coroutines.experimental.CoroutineScope.DefaultImpls
- 
Returns the context of this coroutine. 
- getCoroutineContext() - Method in interface kotlinx.coroutines.experimental.CoroutineScope
- 
Returns the context of this coroutine. 
- getDefaultDispatcher() - Static method in class kotlinx.coroutines.experimental.CoroutineContextKt
- 
- getJob() - Method in exception kotlinx.coroutines.experimental.JobCancellationException
- 
The job that was cancelled. 
- getName() - Method in class kotlinx.coroutines.experimental.CoroutineName
- 
User-defined coroutine name. 
- getOnAwait() - Method in interface kotlinx.coroutines.experimental.Deferred
- 
Clause for select expression of await suspending function that selects with the deferred value when it is
resolved. The select invocation fails if the deferred value completes exceptionally (either fails or
it cancelled). 
- getOnJoin() - Method in interface kotlinx.coroutines.experimental.Job
- 
Clause for select expression of join suspending function that selects when the job is complete.
This clause never fails, even if the job completes exceptionally. 
- getOnJoin() - Method in class kotlinx.coroutines.experimental.NonCancellable
- 
Clause for  select expression of join suspending function that selects when the job is complete.
This clause never fails, even if the job completes exceptionally. 
- getOnLock() - Method in interface kotlinx.coroutines.experimental.sync.Mutex
- 
Clause for select expression of lock suspending function that selects when the mutex is locked.
Additional parameter for the clause in the owner(see lock) and when the clause is selected
the reference to this mutex is passed into the corresponding block.
 
- getOnReceive() - Method in class kotlinx.coroutines.experimental.channels.AbstractChannel
- 
Clause for  select expression of receive suspending function that selects with the element that
is received from the channel.
The  select invocation fails with exception if the channel
isClosedForReceive (see close for details). 
- getOnReceive() - Method in interface kotlinx.coroutines.experimental.channels.ReceiveChannel
- 
Clause for select expression of receive suspending function that selects with the element that
is received from the channel.
The select invocation fails with exception if the channel
isClosedForReceive (see close for details). 
- getOnReceiveOrNull() - Method in class kotlinx.coroutines.experimental.channels.AbstractChannel
- 
Clause for  select expression of receiveOrNull suspending function that selects with the element that
is received from the channel or selects with  null if if the channel
isClosedForReceive without cause. The  select invocation fails with
the original close cause exception if the channel has  failed. 
- getOnReceiveOrNull() - Method in interface kotlinx.coroutines.experimental.channels.ReceiveChannel
- 
Clause for select expression of receiveOrNull suspending function that selects with the element that
is received from the channel or selects with nullif if the channel
isClosedForReceive without cause. The select invocation fails with
the original close cause exception if the channel has failed.
 
- getOnSend() - Method in class kotlinx.coroutines.experimental.channels.AbstractSendChannel
- 
Clause for  select expression of send suspending function that selects when the element that is specified
as parameter is sent to the channel. When the clause is selected the reference to this channel
is passed into the corresponding block. 
- getOnSend() - Method in class kotlinx.coroutines.experimental.channels.ConflatedBroadcastChannel
- 
Clause for  select expression of send suspending function that selects when the element that is specified
as parameter is sent to the channel. When the clause is selected the reference to this channel
is passed into the corresponding block. 
- getOnSend() - Method in interface kotlinx.coroutines.experimental.channels.SendChannel
- 
Clause for select expression of send suspending function that selects when the element that is specified
as parameter is sent to the channel. When the clause is selected the reference to this channel
is passed into the corresponding block. 
- getValue() - Method in class kotlinx.coroutines.experimental.channels.ConflatedBroadcastChannel
- 
The most recently sent element to this channel. 
- getValueOrNull() - Method in class kotlinx.coroutines.experimental.channels.ConflatedBroadcastChannel
- 
The most recently sent element to this channel or nullwhen this class is constructed without
initial value and no value was sent yet or if it was closed.
 
- initCancellability() - Method in interface kotlinx.coroutines.experimental.CancellableContinuation
- 
Makes this continuation cancellable. Use it with  holdCancellability optional parameter to
suspendCancellableCoroutine function. It throws  IllegalStateException if invoked more than once. 
- INITIAL_STATE - Static variable in class kotlinx.coroutines.experimental.channels.ConflatedBroadcastChannel
-  
- INSTANCE - Static variable in class kotlinx.coroutines.experimental.CommonPool
- 
Represents common pool of shared threads as coroutine dispatcher for compute-intensive tasks.
It uses  java.util.concurrent.ForkJoinPool when available, which implements efficient work-stealing algorithm for its queues, so every
coroutine resumption is dispatched as a separate task even when it already executes inside the pool.
When available, it wraps  ForkJoinPool.commonPool and provides a similar shared pool where not. 
- INSTANCE - Static variable in class kotlinx.coroutines.experimental.NonCancellable
- 
A non-cancelable job that is always active. It is designed to be used with run builder
to prevent cancellation of code blocks that need to run without cancellation. 
- INSTANCE - Static variable in class kotlinx.coroutines.experimental.NonDisposableHandle
- 
- INSTANCE - Static variable in class kotlinx.coroutines.experimental.Unconfined
- 
A coroutine dispatcher that is not confined to any specific thread.
It executes initial continuation of the coroutine right here in the current call-frame
and let the coroutine resume in whatever thread that is used by the corresponding suspending function, without
mandating any specific threading policy. 
- interceptContinuation(continuation) - Method in class kotlinx.coroutines.experimental.CoroutineDispatcher
- 
Returns continuation that wraps the original continuation, thus intercepting all resumptions. 
- invoke(block, completion) - Method in enum kotlinx.coroutines.experimental.CoroutineStart
- 
Starts the corresponding block as a coroutine with this coroutine start strategy. 
- invoke(block, receiver, completion) - Method in enum kotlinx.coroutines.experimental.CoroutineStart
- 
Starts the corresponding block with receiver as a coroutine with this coroutine start strategy. 
- invoke($this, $receiver, block) - Static method in class kotlinx.coroutines.experimental.selects.SelectBuilder.DefaultImpls
- 
Registers clause in this select expression with additional parameter nullable parameter of type P
with the nullvalue for this parameter that selects value of type Q.
 
- invoke($receiver, block) - Method in interface kotlinx.coroutines.experimental.selects.SelectBuilder
- 
Registers clause in this select expression without additional parameters that does not select any value. 
- invoke($receiver, block) - Method in interface kotlinx.coroutines.experimental.selects.SelectBuilder
- 
Registers clause in this select expression without additional parameters that selects value of type Q. 
- invoke($receiver, param, block) - Method in interface kotlinx.coroutines.experimental.selects.SelectBuilder
- 
Registers clause in this select expression with additional parameter of type P that selects value of type Q. 
- invoke($receiver, block) - Method in interface kotlinx.coroutines.experimental.selects.SelectBuilder
- 
Registers clause in this select expression with additional parameter nullable parameter of type P
with the nullvalue for this parameter that selects value of type Q.
 
- invokeOnCompletion(onCancelling, handler) - Method in interface kotlinx.coroutines.experimental.Job
- 
Registers handler that is synchronously invoked once on cancellation or completion of this job.
When job is already complete, then the handler is immediately invoked
with a job's cancellation cause or null. Otherwise, handler will be invoked once when this
job is cancelled or complete.
 
- invokeOnCompletion(onCancelling, handler) - Method in class kotlinx.coroutines.experimental.NonCancellable
- 
- invokeOnTimeout($this, time, unit, block) - Static method in class kotlinx.coroutines.experimental.Delay.DefaultImpls
- 
- invokeOnTimeout(time, unit, block) - Method in interface kotlinx.coroutines.experimental.Delay
- 
- isActive() - Method in interface kotlinx.coroutines.experimental.CoroutineScope
- 
Returns truewhen this coroutine is still active (has not completed and was not cancelled yet).
 
- isActive() - Method in interface kotlinx.coroutines.experimental.Job
- 
Returns  true when this job is active -- it was already started and has not completed or cancelled yet.
The job that is waiting for its  Job.attachChild to complete is still considered to be active if it
was not cancelled. 
- isActive() - Method in class kotlinx.coroutines.experimental.NonCancellable
- 
Always returns true.
 
- isBufferAlwaysEmpty() - Method in class kotlinx.coroutines.experimental.channels.ArrayChannel
- 
Returns trueif isBufferEmpty is alwaystrue.
 
- isBufferAlwaysEmpty() - Method in class kotlinx.coroutines.experimental.channels.ConflatedChannel
- 
Returns trueif isBufferEmpty is alwaystrue.
 
- isBufferAlwaysEmpty() - Method in class kotlinx.coroutines.experimental.channels.LinkedListChannel
- 
Returns trueif isBufferEmpty is alwaystrue.
 
- isBufferAlwaysEmpty() - Method in class kotlinx.coroutines.experimental.channels.RendezvousChannel
- 
Returns trueif isBufferEmpty is alwaystrue.
 
- isBufferAlwaysFull() - Method in class kotlinx.coroutines.experimental.channels.ArrayBroadcastChannel
- 
Returns trueif isBufferFull is alwaystrue.
 
- isBufferAlwaysFull() - Method in class kotlinx.coroutines.experimental.channels.ArrayChannel
- 
Returns trueif isBufferFull is alwaystrue.
 
- isBufferAlwaysFull() - Method in class kotlinx.coroutines.experimental.channels.ConflatedChannel
- 
Returns trueif isBufferFull is alwaystrue.
 
- isBufferAlwaysFull() - Method in class kotlinx.coroutines.experimental.channels.LinkedListChannel
- 
Returns trueif isBufferFull is alwaystrue.
 
- isBufferAlwaysFull() - Method in class kotlinx.coroutines.experimental.channels.RendezvousChannel
- 
Returns trueif isBufferFull is alwaystrue.
 
- isBufferEmpty() - Method in class kotlinx.coroutines.experimental.channels.ArrayChannel
- 
Returns trueif this channel's buffer is empty.
 
- isBufferEmpty() - Method in class kotlinx.coroutines.experimental.channels.ConflatedChannel
- 
Returns trueif this channel's buffer is empty.
 
- isBufferEmpty() - Method in class kotlinx.coroutines.experimental.channels.LinkedListChannel
- 
Returns trueif this channel's buffer is empty.
 
- isBufferEmpty() - Method in class kotlinx.coroutines.experimental.channels.RendezvousChannel
- 
Returns trueif this channel's buffer is empty.
 
- isBufferFull() - Method in class kotlinx.coroutines.experimental.channels.ArrayBroadcastChannel
- 
Returns trueif this channel's buffer is full.
 
- isBufferFull() - Method in class kotlinx.coroutines.experimental.channels.ArrayChannel
- 
Returns trueif this channel's buffer is full.
 
- isBufferFull() - Method in class kotlinx.coroutines.experimental.channels.ConflatedChannel
- 
Returns trueif this channel's buffer is full.
 
- isBufferFull() - Method in class kotlinx.coroutines.experimental.channels.LinkedListChannel
- 
Returns trueif this channel's buffer is full.
 
- isBufferFull() - Method in class kotlinx.coroutines.experimental.channels.RendezvousChannel
- 
Returns trueif this channel's buffer is full.
 
- isCancelled() - Method in interface kotlinx.coroutines.experimental.CancellableContinuation
- 
Returns trueif this continuation was cancelled.
 
- isCancelled() - Method in interface kotlinx.coroutines.experimental.Job
- 
Returns trueif this job was cancelled. In the general case, it does not imply that the
job has already completed (it may still be cancelling whatever it was doing).
 
- isCancelled() - Method in class kotlinx.coroutines.experimental.NonCancellable
- 
Always returns false.
 
- isClosedForReceive() - Method in class kotlinx.coroutines.experimental.channels.AbstractChannel
- 
Returns  true if this channel was closed by invocation of close on the  interface SendChannel
side and all previously sent items were already received, so that the receive attempt
throws  exception ClosedReceiveChannelException. If the channel was closed because of the exception, it
is considered closed, too, but it is called a  failed channel. All suspending attempts to receive
an element from a failed channel throw the original close cause exception. 
- isClosedForReceive() - Method in interface kotlinx.coroutines.experimental.channels.ReceiveChannel
- 
Returns  true if this channel was closed by invocation of close on the  interface SendChannel
side and all previously sent items were already received, so that the receive attempt
throws  exception ClosedReceiveChannelException. If the channel was closed because of the exception, it
is considered closed, too, but it is called a  failed channel. All suspending attempts to receive
an element from a failed channel throw the original close cause exception. 
- isClosedForSend() - Method in class kotlinx.coroutines.experimental.channels.AbstractSendChannel
- 
Returns trueif this channel was closed by invocation of close and thus
the send and offer attempts throws exception.
 
- isClosedForSend() - Method in class kotlinx.coroutines.experimental.channels.ConflatedBroadcastChannel
- 
Returns trueif this channel was closed by invocation of close and thus
the send and offer attempts throws exception.
 
- isClosedForSend() - Method in interface kotlinx.coroutines.experimental.channels.SendChannel
- 
Returns trueif this channel was closed by invocation of close and thus
the send and offer attempts throws exception.
 
- isCompleted() - Method in interface kotlinx.coroutines.experimental.Job
- 
Returns  true when this job has completed for any reason. A job that was cancelled and has
finished its execution is also considered complete. Job becomes complete only after
all its  Job.attachChild complete. 
- isCompleted() - Method in class kotlinx.coroutines.experimental.NonCancellable
- 
Always returns false.
 
- isCompletedExceptionally() - Method in interface kotlinx.coroutines.experimental.Deferred
- 
Returns trueif computation of this deferred value has completed exceptionally -- it had
either failed with exception during computation or was cancelled.
 
- isDispatchNeeded(context) - Method in class kotlinx.coroutines.experimental.CoroutineDispatcher
- 
Returns trueif execution shall be dispatched onto another thread.
The default behaviour for most dispatchers is to returntrue.
 
- isDispatchNeeded(context) - Method in class kotlinx.coroutines.experimental.Unconfined
- 
Returns trueif execution shall be dispatched onto another thread.
The default behaviour for most dispatchers is to returntrue.
 
- isEmpty() - Method in class kotlinx.coroutines.experimental.channels.AbstractChannel
- 
Returns trueif the channel is empty (contains no elements) and the receive attempt will suspend.
This function returnsfalsefor isClosedForReceive channel.
 
- isEmpty() - Method in interface kotlinx.coroutines.experimental.channels.ReceiveChannel
- 
Returns trueif the channel is empty (contains no elements) and the receive attempt will suspend.
This function returnsfalsefor isClosedForReceive channel.
 
- isFull() - Method in class kotlinx.coroutines.experimental.channels.AbstractSendChannel
- 
Returns trueif the channel is full (out of capacity) and the send attempt will suspend.
This function returnsfalsefor isClosedForSend channel.
 
- isFull() - Method in class kotlinx.coroutines.experimental.channels.ConflatedBroadcastChannel
- 
Returns trueif the channel is full (out of capacity) and the send attempt will suspend.
This function returnsfalsefor isClosedForSend channel.
 
- isFull() - Method in interface kotlinx.coroutines.experimental.channels.SendChannel
- 
Returns trueif the channel is full (out of capacity) and the send attempt will suspend.
This function returnsfalsefor isClosedForSend channel.
 
- isLazy() - Method in enum kotlinx.coroutines.experimental.CoroutineStart
- 
Returns truewhen LAZY.
 
- isLocked() - Method in interface kotlinx.coroutines.experimental.sync.Mutex
- 
Returns truewhen this mutex is locked.
 
- iterator() - Method in class kotlinx.coroutines.experimental.channels.AbstractChannel
- 
Returns new iterator to receive elements from this channels using forloop.
Iteration completes normally when the channel is isClosedForReceive without cause and
throws the original close cause exception if the channel has failed.
 
- iterator() - Method in interface kotlinx.coroutines.experimental.channels.ReceiveChannel
- 
Returns new iterator to receive elements from this channels using forloop.
Iteration completes normally when the channel is isClosedForReceive without cause and
throws the original close cause exception if the channel has failed.
 
- offer(element) - Method in class kotlinx.coroutines.experimental.channels.AbstractSendChannel
- 
Adds element into this queue if it is possible to do so immediately without violating capacity restrictions
and returns true. Otherwise, it returnsfalseimmediately
or throws exception if the channel isClosedForSend (see close for details).
 
- offer(element) - Method in class kotlinx.coroutines.experimental.channels.ConflatedBroadcastChannel
- 
Sends the value to all subscribed receives and stores this value as the most recent state for
future subscribers. This implementation always returns true.
It throws exception if the channel isClosedForSend (see close for details).
 
- offer(element) - Method in interface kotlinx.coroutines.experimental.channels.SendChannel
- 
Adds element into this queue if it is possible to do so immediately without violating capacity restrictions
and returns true. Otherwise, it returnsfalseimmediately
or throws exception if the channel isClosedForSend (see close for details).
 
- offerInternal(element) - Method in class kotlinx.coroutines.experimental.channels.ArrayBroadcastChannel
- 
Tries to add element to buffer or to queued receiver.
Return type is OFFER_SUCCESS | OFFER_FAILED | Closed.
 
- offerInternal(element) - Method in class kotlinx.coroutines.experimental.channels.ArrayChannel
- 
Tries to add element to buffer or to queued receiver.
Return type is OFFER_SUCCESS | OFFER_FAILED | Closed.
 
- offerInternal(element) - Method in class kotlinx.coroutines.experimental.channels.ConflatedChannel
- 
Tries to add element to buffer or to queued receiver.
Return type is OFFER_SUCCESS | OFFER_FAILED | Closed.
 
- offerInternal(element) - Method in class kotlinx.coroutines.experimental.channels.LinkedListChannel
- 
Tries to add element to buffer or to queued receiver.
Return type is OFFER_SUCCESS | OFFER_FAILED | Closed.
 
- offerSelectInternal(element, select) - Method in class kotlinx.coroutines.experimental.channels.ArrayBroadcastChannel
- 
Tries to add element to buffer or to queued receiver if select statement clause was not selected yet.
Return type is ALREADY_SELECTED | OFFER_SUCCESS | OFFER_FAILED | Closed.
 
- offerSelectInternal(element, select) - Method in class kotlinx.coroutines.experimental.channels.ArrayChannel
- 
Tries to add element to buffer or to queued receiver if select statement clause was not selected yet.
Return type is ALREADY_SELECTED | OFFER_SUCCESS | OFFER_FAILED | Closed.
 
- offerSelectInternal(element, select) - Method in class kotlinx.coroutines.experimental.channels.ConflatedChannel
- 
Tries to add element to buffer or to queued receiver if select statement clause was not selected yet.
Return type is ALREADY_SELECTED | OFFER_SUCCESS | OFFER_FAILED | Closed.
 
- offerSelectInternal(element, select) - Method in class kotlinx.coroutines.experimental.channels.LinkedListChannel
- 
Tries to add element to buffer or to queued receiver if select statement clause was not selected yet.
Return type is ALREADY_SELECTED | OFFER_SUCCESS | OFFER_FAILED | Closed.
 
- onCancelledReceive() - Method in class kotlinx.coroutines.experimental.channels.AbstractChannel
- 
Invoked when enqueued receiver was successfully cancelled. 
- onEnqueuedReceive() - Method in class kotlinx.coroutines.experimental.channels.AbstractChannel
- 
Invoked when receiver is successfully enqueued to the queue of waiting receivers. 
- onTimeout(time, unit, block) - Method in interface kotlinx.coroutines.experimental.selects.SelectBuilder
- 
Clause that selects the given block after a specified timeout passes. 
- openSubscription() - Method in class kotlinx.coroutines.experimental.channels.ArrayBroadcastChannel
- 
- openSubscription() - Method in interface kotlinx.coroutines.experimental.channels.BroadcastChannel
- 
- openSubscription() - Method in class kotlinx.coroutines.experimental.channels.ConflatedBroadcastChannel
- 
- ScheduledKt - Class in kotlinx.coroutines.experimental
-  
- scheduleResumeAfterDelay(time, unit, continuation) - Method in interface kotlinx.coroutines.experimental.Delay
- 
Schedules resume of a specified continuation after a specified delay time. 
- select(builder, $continuation) - Static method in class kotlinx.coroutines.experimental.selects.SelectKt
- 
Waits for the result of multiple suspending functions simultaneously, which are specified using clauses
in the builder scope of this select invocation. The caller is suspended until one of the clauses
is either selected or fails. 
- SelectBuilder<R> - Interface in kotlinx.coroutines.experimental.selects
- 
Scope for select invocation. 
- SelectBuilder.DefaultImpls - Class in kotlinx.coroutines.experimental.selects
- 
Scope for select invocation. 
- SelectClause0 - Interface in kotlinx.coroutines.experimental.selects
- 
Clause for select expression without additional parameters that does not select any value. 
- SelectClause1<Q> - Interface in kotlinx.coroutines.experimental.selects
- 
Clause for select expression without additional parameters that selects value of type Q. 
- SelectClause2<P,Q> - Interface in kotlinx.coroutines.experimental.selects
- 
Clause for select expression with additional parameter of type P that selects value of type Q. 
- SelectKt - Class in kotlinx.coroutines.experimental.selects
-  
- selectUnbiased(builder, $continuation) - Static method in class kotlinx.coroutines.experimental.selects.SelectUnbiasedKt
- 
Waits for the result of multiple suspending functions simultaneously like select, but in an unbiased
way when multiple clauses are selectable at the same time. 
- SelectUnbiasedKt - Class in kotlinx.coroutines.experimental.selects
-  
- send(element, $continuation) - Method in class kotlinx.coroutines.experimental.channels.AbstractSendChannel
- 
Adds element into to this channel, suspending the caller while this channel isFull,
or throws exception if the channel isClosedForSend (see close for details). 
- send(element, $continuation) - Method in class kotlinx.coroutines.experimental.channels.ConflatedBroadcastChannel
- 
Sends the value to all subscribed receives and stores this value as the most recent state for
future subscribers. This implementation never suspends.
It throws exception if the channel isClosedForSend (see close for details). 
- send(element, $continuation) - Method in interface kotlinx.coroutines.experimental.channels.SendChannel
- 
Adds element into to this channel, suspending the caller while this channel isFull,
or throws exception if the channel isClosedForSend (see close for details). 
- SendChannel<E> - Interface in kotlinx.coroutines.experimental.channels
- 
- start() - Method in interface kotlinx.coroutines.experimental.Job
- 
Starts coroutine related to this job (if any) if it was not started yet.
The result trueif this invocation actually started coroutine orfalseif it was already started or completed.
 
- start() - Method in class kotlinx.coroutines.experimental.NonCancellable
- 
Always returns false.
 
- SubscriptionReceiveChannel<T> - Interface in kotlinx.coroutines.experimental.channels
- 
- suspendAtomicCancellableCoroutine(holdCancellability, block, $continuation) - Static method in class kotlinx.coroutines.experimental.CancellableContinuationKt
- 
Suspends coroutine similar to suspendCancellableCoroutine, but with atomic cancellation. 
- suspendCancellableCoroutine(holdCancellability, block, $continuation) - Static method in class kotlinx.coroutines.experimental.CancellableContinuationKt
-