- cancel(cause) - Method in interface kotlinx.coroutines.experimental.CancellableContinuation
-
Cancels this continuation with an optional cancellation cause. The result is true
if this continuation was
cancelled as a result of this invocation and false
otherwise.
- 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, p) - 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
Job.getChildren
jobs of this coroutine with the given cause using
Job.cancel
for all of them. Unlike
Job.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
CancellableContinuation.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
-
- 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
-
- close($this) - Static method in class kotlinx.coroutines.experimental.channels.SubscriptionReceiveChannel.DefaultImpls
-
- 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
-
- ClosedReceiveChannelException(message) - Constructor for exception kotlinx.coroutines.experimental.channels.ClosedReceiveChannelException
-
- ClosedSendChannelException - Exception in kotlinx.coroutines.experimental.channels
-
- ClosedSendChannelException(message) - Constructor for exception kotlinx.coroutines.experimental.channels.ClosedSendChannelException
-
- CommonCompletionHandlerKt - Class in kotlinx.coroutines.experimental
-
- 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
-
Deprecated.
- CompletableDeferred<T> - Interface in kotlinx.coroutines.experimental
-
- 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
-
- 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
ReceiveChannel.cancel
after the execution of the block.
- copy(name) - Method in class kotlinx.coroutines.experimental.CoroutineName
-
- 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
-
- CoroutineName(name) - Constructor for class kotlinx.coroutines.experimental.CoroutineName
-
- CoroutineName.Key - Class in kotlinx.coroutines.experimental
-
- CoroutineScope - Interface in kotlinx.coroutines.experimental
-
- CoroutineScope.DefaultImpls - Class in kotlinx.coroutines.experimental
-
- CoroutineStart - Enum in kotlinx.coroutines.experimental
-
Defines start option for coroutines builders.
It is used in
start
parameter of launch, async, and
ActorKt.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
ActorKt.actor
coroutine builder functions.
- count($receiver, p) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns the number of elements in this channel.
- DebugKt - Class in kotlinx.coroutines.experimental
-
- Deferred<T> - Interface in kotlinx.coroutines.experimental
-
Deferred value is a non-blocking cancellable future.
- Deferred.DefaultImpls - Class in kotlinx.coroutines.experimental
-
Deferred value is a non-blocking cancellable future.
- DeferredKt - Class in kotlinx.coroutines.experimental
-
- Delay - Interface in kotlinx.coroutines.experimental
-
This dispatcher
feature is implemented by
class CoroutineDispatcher
implementations that natively support
scheduled execution of tasks.
- delay($this, time, unit, p) - Static method in class kotlinx.coroutines.experimental.Delay.DefaultImpls
-
Delays coroutine for a given time without blocking a thread and resumes it after a specified time.
This suspending function is cancellable.
If the
interface Job
of the current coroutine is cancelled or completed while this suspending function is waiting, this function
immediately resumes with CancellationException.
- delay(time, unit, p) - Method in interface kotlinx.coroutines.experimental.Delay
-
Delays coroutine for a given time without blocking a thread and resumes it after a specified time.
This suspending function is cancellable.
If the
interface Job
of the current coroutine is cancelled or completed while this suspending function is waiting, this function
immediately resumes with CancellationException.
- delay(time, p) - Static method in class kotlinx.coroutines.experimental.DelayKt
-
Delays coroutine for a given time without blocking a thread and resumes it after a specified time.
This suspending function is cancellable.
If the
interface Job
of the current coroutine is cancelled or completed while this suspending function is waiting, this function
immediately resumes with CancellationException.
- delay(time, unit, p) - Static method in class kotlinx.coroutines.experimental.DelayKt
-
Delays coroutine for a given time without blocking a thread and resumes it after a specified time.
This suspending function is cancellable.
If the
interface Job
of the current coroutine is cancelled or completed while this suspending function is waiting, this function
immediately resumes with CancellationException.
- Delay.DefaultImpls - Class in kotlinx.coroutines.experimental
-
This dispatcher
feature is implemented by
class CoroutineDispatcher
implementations that natively support
scheduled execution of tasks.
- DelayKt - Class in kotlinx.coroutines.experimental
-
- dispatch(context, block) - Method in class kotlinx.coroutines.experimental.CommonPool
-
Dispatches execution of a runnable block onto another thread in the given context.
- dispatch(context, block) - Method in class kotlinx.coroutines.experimental.CoroutineDispatcher
-
Dispatches execution of a runnable block onto another thread in the given context.
- dispatch(context, block) - Method in class kotlinx.coroutines.experimental.Unconfined
-
Dispatches execution of a runnable block onto another thread in the given context.
- DispatchedKt - Class in kotlinx.coroutines.experimental
-
- DisposableHandle - Interface in kotlinx.coroutines.experimental
-
A handle to an allocated object that can be disposed to make it eligible for garbage collection.
- DisposableHandle.DefaultImpls - Class in kotlinx.coroutines.experimental
-
A handle to an allocated object that can be disposed to make it eligible for garbage collection.
- dispose() - Method in interface kotlinx.coroutines.experimental.DisposableHandle
-
Disposes the corresponding object, making it eligible for garbage collection.
Repeated invocation of this function has no effect.
- dispose() - Method in class kotlinx.coroutines.experimental.NonDisposableHandle
-
Does not do anything.
- disposeOnCompletion($receiver, handle) - Static method in class kotlinx.coroutines.experimental.JobKt
-
Disposes a specified handle when this job is complete.
- distinct($receiver) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns a channel containing only distinct elements from the given channel.
- distinctBy($receiver, context, selector) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns a channel containing only elements from the given channel
having distinct keys returned by the given selector function.
- drop($receiver, n, context) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns a channel containing all elements except first n elements.
- dropWhile($receiver, context, predicate) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns a channel containing all elements except first elements that satisfy the given predicate.
- indexOf($receiver, element, p) - Static method in class kotlinx.coroutines.experimental.channels.ChannelsKt
-
Returns first index of element, or -1 if the channel does not contain 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
NonCancellable.isActive
. It is designed for withContext function
to prevent cancellation of code blocks that need to be executed 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(handler) - Method in interface kotlinx.coroutines.experimental.CancellableContinuation
-
Registers handler that is synchronously invoked once on completion of this continuation.
When continuation is already complete, then the handler is immediately invoked
with continuation's exception or null
. Otherwise, handler will be invoked once when this
continuation is complete.
- invokeOnCompletion(handler) - Method in interface kotlinx.coroutines.experimental.Job
-
Registers handler that is synchronously invoked once on completion of this job.
When job is already complete, then the handler is immediately invoked
with a job's exception or cancellation cause or null
. Otherwise, handler will be invoked once when this
job is complete.
- invokeOnCompletion(onCancelling, invokeImmediately, 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 cancelling or complete, then the handler is immediately invoked
with a job's cancellation cause or null
unless invokeImmediately is set to false.
Otherwise, handler will be invoked once when this job is cancelled or complete.
- invokeOnCompletion(handler) - Method in class kotlinx.coroutines.experimental.NonCancellable
-
- invokeOnCompletion(onCancelling_, handler) - Method in class kotlinx.coroutines.experimental.NonCancellable
-
- invokeOnCompletion(onCancelling, invokeImmediately, 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.CancellableContinuation
-
Returns true
when this continuation is active -- it has not completed or cancelled yet.
- 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
Job.getChildren
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
-
- isBufferAlwaysEmpty() - Method in class kotlinx.coroutines.experimental.channels.ConflatedChannel
-
- isBufferAlwaysEmpty() - Method in class kotlinx.coroutines.experimental.channels.LinkedListChannel
-
- isBufferAlwaysEmpty() - Method in class kotlinx.coroutines.experimental.channels.RendezvousChannel
-
- isBufferAlwaysFull() - Method in class kotlinx.coroutines.experimental.channels.ArrayBroadcastChannel
-
- isBufferAlwaysFull() - Method in class kotlinx.coroutines.experimental.channels.ArrayChannel
-
- isBufferAlwaysFull() - Method in class kotlinx.coroutines.experimental.channels.ConflatedChannel
-
- isBufferAlwaysFull() - Method in class kotlinx.coroutines.experimental.channels.LinkedListChannel
-
- isBufferAlwaysFull() - Method in class kotlinx.coroutines.experimental.channels.RendezvousChannel
-
- 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
-
- isCancelled() - Method in interface kotlinx.coroutines.experimental.Job
-
Returns
true
if this job was
Job.cancel
. In the general case, it does not imply that the
job has already
Job.isCompleted
(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
-
- isClosedForReceive() - Method in interface kotlinx.coroutines.experimental.channels.ReceiveChannel
-
- isClosedForSend() - Method in class kotlinx.coroutines.experimental.channels.AbstractSendChannel
-
- isClosedForSend() - Method in class kotlinx.coroutines.experimental.channels.ConflatedBroadcastChannel
-
- isClosedForSend() - Method in interface kotlinx.coroutines.experimental.channels.SendChannel
-
- isCompleted() - Method in interface kotlinx.coroutines.experimental.CancellableContinuation
-
Returns true
when this continuation has completed for any reason. A continuation
that was cancelled is also considered complete.
- 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.getChildren
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
Job.cancel
.
- 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
-
- isEmpty() - Method in interface kotlinx.coroutines.experimental.channels.ReceiveChannel
-
- isFull() - Method in class kotlinx.coroutines.experimental.channels.AbstractSendChannel
-
- isFull() - Method in class kotlinx.coroutines.experimental.channels.ConflatedBroadcastChannel
-
- isFull() - Method in interface kotlinx.coroutines.experimental.channels.SendChannel
-
- 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
AbstractChannel.isClosedForReceive
without cause and
throws the original
SendChannel.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
ReceiveChannel.isClosedForReceive
without cause and
throws the original
SendChannel.close
cause exception if the channel has
failed.