- 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, parent, 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 ActorJob. The resulting
object can be used to send messages to this coroutine.
- 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.
- all($receiver, predicate, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns true
if all elements match the given predicate.
- any($receiver, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns true
if channel has at least one element.
- any($receiver, predicate, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns true
if at least one element matches the given predicate.
- 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
-
- asReceiveChannel($receiver, context) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns a channel to read all element of the
Iterable.
- asReceiveChannel($receiver, context) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns a channel to read all element of the
Sequence.
- associate($receiver, transform, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns a
Map containing key-value pairs provided by transform function
applied to elements of the given channel.
- associateBy($receiver, keySelector, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns a
Map containing the elements from the given channel indexed by the key
returned from keySelector function applied to each element.
- associateBy($receiver, keySelector, valueTransform, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns a
Map containing the values provided by valueTransform and indexed by keySelector functions applied to elements of the given channel.
- associateByTo($receiver, destination, keySelector, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Populates and returns the destination mutable map with key-value pairs,
where key is provided by the keySelector function applied to each element of the given channel
and value is the element itself.
- associateByTo($receiver, destination, keySelector, valueTransform, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Populates and returns the destination mutable map with key-value pairs,
where key is provided by the keySelector function and
and value is provided by the valueTransform function applied to elements of the given channel.
- associateTo($receiver, destination, transform, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Populates and returns the destination mutable map with key-value pairs
provided by transform function applied to each element of the given channel.
- async(context, start, parent, 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 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 class kotlinx.coroutines.experimental.channels.AbstractChannel
-
Cancels reception of remaining elements from this channel. This function closes the channel with
the specified cause (unless it was already closed) and removes all buffered sent elements from it.
This function returns true
if the channel was not closed previously, or false
otherwise.
- cancel(cause) - Method in interface kotlinx.coroutines.experimental.channels.ReceiveChannel
-
Cancels reception of remaining elements from this channel. This function closes the channel with
the specified cause (unless it was already closed) and removes all buffered sent elements from it.
This function returns true
if the channel was not closed previously, or false
otherwise.
- 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($receiver, cause) - Static method in class kotlinx.coroutines.experimental.JobKt
-
Cancels all children jobs of this coroutine with the given cause using cancel
for all of them. Unlike cancel on this job as a whole, 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.
- 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 is a non-blocking primitive for communication between sender using
interface SendChannel
and receiver using
interface ReceiveChannel
.
Conceptually, a channel is similar to BlockingQueue,
but it has suspending operations instead of blocking ones and it can be closed.
- 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
-
- cleanupSendQueueOnCancel() - Method in class kotlinx.coroutines.experimental.channels.AbstractChannel
-
- cleanupSendQueueOnCancel() - Method in class kotlinx.coroutines.experimental.channels.ArrayChannel
-
- 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.
- 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.
- 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.
- 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.
- close() - Method in interface kotlinx.coroutines.experimental.channels.SubscriptionReceiveChannel
-
Closes this subscription. This is a synonym for cancel.
- close($this) - Static method in class kotlinx.coroutines.experimental.channels.SubscriptionReceiveChannel.DefaultImpls
-
Closes this subscription. This is a synonym for cancel.
- close() - Method in class kotlinx.coroutines.experimental.ThreadPoolDispatcher
-
Closes this dispatcher -- shuts down all threads in this pool and releases resources.
- 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(parent) - 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 true
if this deferred was
completed as a result of this invocation and false
otherwise (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 true
if this deferred was
completed as a result of this invocation and false
otherwise (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 send
and offer
invocations,
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 returns true
.
- ConflatedChannel() - Constructor for class kotlinx.coroutines.experimental.channels.ConflatedChannel
-
Channel that buffers at most one element and conflates all subsequent send
and offer
invocations,
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 returns true
.
- consume($receiver, block) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Opens subscription to this
interface BroadcastChannel
and makes sure that the given block consumes all elements
from it by always invoking cancel after the execution of the block.
- consume($receiver, block) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Makes sure that the given block consumes all elements from the given channel
by always invoking cancel after the execution of the block.
- consumeEach($receiver, action, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
- consumeEach($receiver, action, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Performs the given action for each received element.
- consumeEachIndexed($receiver, action, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Performs the given action for each received element.
- 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 start
parameter 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 start
parameter of launch, async, and actor
coroutine builder functions.
- count($receiver, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns the number of elements in this channel.
- count($receiver, predicate, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns the number of elements matching the given predicate.
- Factory - Static variable in interface kotlinx.coroutines.experimental.channels.Channel
-
Constants for channel factory function Channel()
.
- filter($receiver, context, predicate) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns a channel containing only elements matching the given predicate.
- filterIndexed($receiver, context, predicate) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns a channel containing only elements matching the given predicate.
- filterIndexedTo($receiver, destination, predicate, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Appends all elements matching the given predicate to the given destination.
- filterIndexedTo($receiver, destination, predicate, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Appends all elements matching the given predicate to the given destination.
- filterNot($receiver, predicate) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns a channel containing all elements not matching the given predicate.
- filterNotNull($receiver) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns a channel containing all elements that are not null
.
- filterNotNullTo($receiver, destination, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Appends all elements that are not null
to the given destination.
- filterNotNullTo($receiver, destination, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Appends all elements that are not null
to the given destination.
- filterNotTo($receiver, destination, predicate, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Appends all elements not matching the given predicate to the given destination.
- filterNotTo($receiver, destination, predicate, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Appends all elements not matching the given predicate to the given destination.
- filterTo($receiver, destination, predicate, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Appends all elements matching the given predicate to the given destination.
- filterTo($receiver, destination, predicate, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Appends all elements matching the given predicate to the given destination.
- find($receiver, predicate, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns the first element matching the given predicate, or null
if no such element was found.
- findLast($receiver, predicate, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns the last element matching the given predicate, or null
if no such element was found.
- first($receiver, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns first element.
- first($receiver, predicate, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns the first element matching the given predicate.
- firstOrNull($receiver, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns the first element, or null
if the channel is empty.
- firstOrNull($receiver, predicate, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns the first element matching the given predicate, or null
if element was not found.
- flatMap($receiver, context, transform) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns a single channel of all elements from results of transform function being invoked on each element of original channel.
- fold($receiver, initial, operation, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Accumulates value starting with initial value and applying operation from left to right to current accumulator value and each element.
- fold($this, initial, operation) - Static method in class kotlinx.coroutines.experimental.Deferred.DefaultImpls
-
- fold($this, initial, operation) - Static method in class kotlinx.coroutines.experimental.Job.DefaultImpls
-
- foldIndexed($receiver, initial, operation, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Accumulates value starting with initial value and applying operation from left to right
to current accumulator value and each element with its index in the original channel.
- 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.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.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.
- getChildren() - Method in interface kotlinx.coroutines.experimental.Job
-
Returns a sequence of this job's children.
- getChildren() - Method in class kotlinx.coroutines.experimental.NonCancellable
-
- 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 null
if 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 null
when this class is constructed without
initial value and no value was sent yet or if it was closed.
- groupBy($receiver, keySelector, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Groups elements of the original channel by the key returned by the given keySelector function
applied to each element and returns a map where each group key is associated with a list of corresponding elements.
- groupBy($receiver, keySelector, valueTransform, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Groups values returned by the valueTransform function applied to each element of the original channel
by the key returned by the given keySelector function applied to the element
and returns a map where each group key is associated with a list of corresponding values.
- groupByTo($receiver, destination, keySelector, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Groups elements of the original channel by the key returned by the given keySelector function
applied to each element and puts to the destination map each group key associated with a list of corresponding elements.
- groupByTo($receiver, destination, keySelector, valueTransform, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Groups values returned by the valueTransform function applied to each element of the original channel
by the key returned by the given keySelector function applied to the element
and puts to the destination map each group key associated with a list of corresponding values.
- indexOf($receiver, element, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns first index of element, or -1 if the channel does not contain element.
- indexOfFirst($receiver, predicate, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns index of the first element matching the given predicate, or -1 if the channel does not contain such element.
- indexOfLast($receiver, predicate, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns index of the last element matching the given predicate, or -1 if the channel does not contain such element.
- 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 null
value 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 null
value 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 true
when 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 children 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 true
if isBufferEmpty is always true
.
- isBufferAlwaysEmpty() - Method in class kotlinx.coroutines.experimental.channels.ConflatedChannel
-
Returns true
if isBufferEmpty is always true
.
- isBufferAlwaysEmpty() - Method in class kotlinx.coroutines.experimental.channels.LinkedListChannel
-
Returns true
if isBufferEmpty is always true
.
- isBufferAlwaysEmpty() - Method in class kotlinx.coroutines.experimental.channels.RendezvousChannel
-
Returns true
if isBufferEmpty is always true
.
- isBufferAlwaysFull() - Method in class kotlinx.coroutines.experimental.channels.ArrayBroadcastChannel
-
Returns true
if isBufferFull is always true
.
- isBufferAlwaysFull() - Method in class kotlinx.coroutines.experimental.channels.ArrayChannel
-
Returns true
if isBufferFull is always true
.
- isBufferAlwaysFull() - Method in class kotlinx.coroutines.experimental.channels.ConflatedChannel
-
Returns true
if isBufferFull is always true
.
- isBufferAlwaysFull() - Method in class kotlinx.coroutines.experimental.channels.LinkedListChannel
-
Returns true
if isBufferFull is always true
.
- isBufferAlwaysFull() - Method in class kotlinx.coroutines.experimental.channels.RendezvousChannel
-
Returns true
if isBufferFull is always true
.
- isBufferEmpty() - Method in class kotlinx.coroutines.experimental.channels.ArrayChannel
-
Returns true
if this channel's buffer is empty.
- isBufferEmpty() - Method in class kotlinx.coroutines.experimental.channels.ConflatedChannel
-
Returns true
if this channel's buffer is empty.
- isBufferEmpty() - Method in class kotlinx.coroutines.experimental.channels.LinkedListChannel
-
Returns true
if this channel's buffer is empty.
- isBufferEmpty() - Method in class kotlinx.coroutines.experimental.channels.RendezvousChannel
-
Returns true
if this channel's buffer is empty.
- isBufferFull() - Method in class kotlinx.coroutines.experimental.channels.ArrayBroadcastChannel
-
Returns true
if this channel's buffer is full.
- isBufferFull() - Method in class kotlinx.coroutines.experimental.channels.ArrayChannel
-
Returns true
if this channel's buffer is full.
- isBufferFull() - Method in class kotlinx.coroutines.experimental.channels.ConflatedChannel
-
Returns true
if this channel's buffer is full.
- isBufferFull() - Method in class kotlinx.coroutines.experimental.channels.LinkedListChannel
-
Returns true
if this channel's buffer is full.
- isBufferFull() - Method in class kotlinx.coroutines.experimental.channels.RendezvousChannel
-
Returns true
if this channel's buffer is full.
- isCancelled() - Method in interface kotlinx.coroutines.experimental.CancellableContinuation
-
Returns true
if this continuation was cancelled.
- isCancelled() - Method in interface kotlinx.coroutines.experimental.Job
-
Returns true
if 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 true
if 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 true
if 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 true
if 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 children complete.
- isCompleted() - Method in class kotlinx.coroutines.experimental.NonCancellable
-
Always returns false
.
- isCompletedExceptionally() - Method in interface kotlinx.coroutines.experimental.Deferred
-
Returns true
if 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 true
if execution shall be dispatched onto another thread.
The default behaviour for most dispatchers is to return true
.
- isDispatchNeeded(context) - Method in class kotlinx.coroutines.experimental.Unconfined
-
Returns true
if execution shall be dispatched onto another thread.
The default behaviour for most dispatchers is to return true
.
- isEmpty() - Method in class kotlinx.coroutines.experimental.channels.AbstractChannel
-
Returns true
if the channel is empty (contains no elements) and the receive attempt will suspend.
This function returns false
for isClosedForReceive channel.
- isEmpty() - Method in interface kotlinx.coroutines.experimental.channels.ReceiveChannel
-
Returns true
if the channel is empty (contains no elements) and the receive attempt will suspend.
This function returns false
for isClosedForReceive channel.
- isFull() - Method in class kotlinx.coroutines.experimental.channels.AbstractSendChannel
-
Returns true
if the channel is full (out of capacity) and the send attempt will suspend.
This function returns false
for isClosedForSend channel.
- isFull() - Method in class kotlinx.coroutines.experimental.channels.ConflatedBroadcastChannel
-
Returns true
if the channel is full (out of capacity) and the send attempt will suspend.
This function returns false
for isClosedForSend channel.
- isFull() - Method in interface kotlinx.coroutines.experimental.channels.SendChannel
-
Returns true
if the channel is full (out of capacity) and the send attempt will suspend.
This function returns false
for isClosedForSend channel.
- isLazy() - Method in enum kotlinx.coroutines.experimental.CoroutineStart
-
Returns true
when LAZY.
- isLocked() - Method in interface kotlinx.coroutines.experimental.sync.Mutex
-
Returns true
when this mutex is locked.
- iterator() - Method in class kotlinx.coroutines.experimental.channels.AbstractChannel
-
Returns new iterator to receive elements from this channels using for
loop.
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 for
loop.
Iteration completes normally when the channel is isClosedForReceive without cause and
throws the original close cause exception if the channel has failed.
- map($receiver, context, transform) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns a channel containing the results of applying the given transform function
to each element in the original channel.
- mapIndexed($receiver, context, transform) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns a channel containing the results of applying the given transform function
to each element and its index in the original channel.
- mapIndexedNotNull($receiver, context, transform) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns a channel containing only the non-null results of applying the given transform function
to each element and its index in the original channel.
- mapIndexedNotNullTo($receiver, destination, transform, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Applies the given transform function to each element and its index in the original channel
and appends only the non-null results to the given destination.
- mapIndexedNotNullTo($receiver, destination, transform, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Applies the given transform function to each element and its index in the original channel
and appends only the non-null results to the given destination.
- mapIndexedTo($receiver, destination, transform, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Applies the given transform function to each element and its index in the original channel
and appends the results to the given destination.
- mapIndexedTo($receiver, destination, transform, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Applies the given transform function to each element and its index in the original channel
and appends the results to the given destination.
- mapNotNull($receiver, context, transform) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns a channel containing only the non-null results of applying the given transform function
to each element in the original channel.
- mapNotNullTo($receiver, destination, transform, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Applies the given transform function to each element in the original channel
and appends only the non-null results to the given destination.
- mapNotNullTo($receiver, destination, transform, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Applies the given transform function to each element in the original channel
and appends only the non-null results to the given destination.
- mapTo($receiver, destination, transform, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Applies the given transform function to each element of the original channel
and appends the results to the given destination.
- mapTo($receiver, destination, transform, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Applies the given transform function to each element of the original channel
and appends the results to the given destination.
- maxBy($receiver, selector, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns the first element yielding the largest value of the given function or null
if there are no elements.
- maxWith($receiver, comparator, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns the first element having the largest value according to the provided comparator or null
if there are no elements.
- minBy($receiver, selector, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns the first element yielding the smallest value of the given function or null
if there are no elements.
- minusKey($this, key) - Static method in class kotlinx.coroutines.experimental.Deferred.DefaultImpls
-
- minusKey($this, key) - Static method in class kotlinx.coroutines.experimental.Job.DefaultImpls
-
- minWith($receiver, comparator, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns the first element having the smallest value according to the provided comparator or null
if there are no elements.
- Mutex - Interface in kotlinx.coroutines.experimental.sync
-
Mutual exclusion for coroutines.
- Mutex(locked) - Static method in class kotlinx.coroutines.experimental.sync.MutexKt
-
Creates new
interface Mutex
instance.
The mutex created is fair: lock is granted in first come, first served order.
- MutexKt - Class in kotlinx.coroutines.experimental.sync
-
- 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 returns false
immediately
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 returns false
immediately
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).
- sendBlocking($receiver, element) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Adds element into to this channel, blocking the caller while this channel Channel.isFull,
or throws exception if the channel Channel.isClosedForSend (see Channel.close for details).
- SendChannel<E> - Interface in kotlinx.coroutines.experimental.channels
-
- single($receiver, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns the single element, or throws an exception if the channel is empty or has more than one element.
- single($receiver, predicate, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns the single element matching the given predicate, or throws exception if there is no or more than one matching element.
- singleOrNull($receiver, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns single element, or null
if the channel is empty or has more than one element.
- singleOrNull($receiver, predicate, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns the single element matching the given predicate, or null
if element was not found or more than one element was found.
- start() - Method in interface kotlinx.coroutines.experimental.Job
-
Starts coroutine related to this job (if any) if it was not started yet.
The result true
if this invocation actually started coroutine or false
if 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
-
- SubscriptionReceiveChannel.DefaultImpls - Class in kotlinx.coroutines.experimental.channels
-
- sumBy($receiver, selector, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns the sum of all values produced by selector function applied to each element in the channel.
- sumByDouble($receiver, selector, $continuation) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns the sum of all values produced by selector function applied to each element in the channel.
- 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
-