Uses of Interface
org.apache.flink.util.function.ThrowingRunnable
-
-
Uses of ThrowingRunnable in org.apache.flink.api.common.operators
Methods in org.apache.flink.api.common.operators with parameters of type ThrowingRunnable Modifier and Type Method Description default void
MailboxExecutor. execute(MailboxExecutor.MailOptions mailOptions, ThrowingRunnable<? extends Exception> command, String description)
Executes the given command at some time in the future in the mailbox thread.void
MailboxExecutor. execute(MailboxExecutor.MailOptions mailOptions, ThrowingRunnable<? extends Exception> command, String descriptionFormat, Object... descriptionArgs)
Executes the given command at some time in the future in the mailbox thread.default void
MailboxExecutor. execute(ThrowingRunnable<? extends Exception> command, String description)
Executes the given command at some time in the future in the mailbox thread.default void
MailboxExecutor. execute(ThrowingRunnable<? extends Exception> command, String descriptionFormat, Object... descriptionArgs)
Executes the given command at some time in the future in the mailbox thread. -
Uses of ThrowingRunnable in org.apache.flink.connector.file.src.util
Methods in org.apache.flink.connector.file.src.util with parameters of type ThrowingRunnable Modifier and Type Method Description static void
Utils. doWithCleanupOnException(Closeable toCleanUp, ThrowingRunnable<IOException> code)
Runs the givenRunnable
. -
Uses of ThrowingRunnable in org.apache.flink.core.state
Methods in org.apache.flink.core.state with parameters of type ThrowingRunnable Modifier and Type Method Description void
StateFutureImpl.CallbackRunner. submit(ThrowingRunnable<? extends Exception> task)
-
Uses of ThrowingRunnable in org.apache.flink.runtime.asyncprocessing
Methods in org.apache.flink.runtime.asyncprocessing with parameters of type ThrowingRunnable Modifier and Type Method Description void
AsyncExecutionController. processNonRecord(ThrowingRunnable<? extends Exception> action)
void
BatchCallbackRunner. submit(ThrowingRunnable<? extends Exception> task)
Submit a callback to run.void
AsyncExecutionController. syncPointRequestWithCallback(ThrowingRunnable<Exception> callback)
A helper to request aStateRequestType.SYNC_POINT
and run a callback if it finishes (once the record is not blocked). -
Uses of ThrowingRunnable in org.apache.flink.runtime.asyncprocessing.operators
Methods in org.apache.flink.runtime.asyncprocessing.operators with parameters of type ThrowingRunnable Modifier and Type Method Description <K> void
AbstractAsyncStateStreamOperator. asyncProcessWithKey(K key, ThrowingRunnable<Exception> processing)
<K> void
AbstractAsyncStateStreamOperatorV2. asyncProcessWithKey(K key, ThrowingRunnable<Exception> processing)
void
AbstractAsyncStateStreamOperator. preserveRecordOrderAndProcess(ThrowingRunnable<Exception> processing)
void
AbstractAsyncStateStreamOperatorV2. preserveRecordOrderAndProcess(ThrowingRunnable<Exception> processing)
-
Uses of ThrowingRunnable in org.apache.flink.runtime.concurrent
Methods in org.apache.flink.runtime.concurrent with parameters of type ThrowingRunnable Modifier and Type Method Description static <T extends Throwable>
voidClassLoadingUtils. runWithContextClassLoader(ThrowingRunnable<T> runnable, ClassLoader contextClassLoader)
Runs the given runnable in aTemporaryClassLoaderContext
to prevent the plugin class loader from leaking into Flink. -
Uses of ThrowingRunnable in org.apache.flink.runtime.memory
Constructors in org.apache.flink.runtime.memory with parameters of type ThrowingRunnable Constructor Description OpaqueMemoryResource(T resourceHandle, long size, ThrowingRunnable<Exception> disposer)
-
Uses of ThrowingRunnable in org.apache.flink.runtime.operators.coordination
Methods in org.apache.flink.runtime.operators.coordination with parameters of type ThrowingRunnable Modifier and Type Method Description static CompletableFuture<Void>
ComponentClosingUtils. closeAsyncWithTimeout(String componentName, ThrowingRunnable<Exception> closingSequence, Duration closeTimeout)
Close a component with a timeout. -
Uses of ThrowingRunnable in org.apache.flink.runtime.state.ttl
Methods in org.apache.flink.runtime.state.ttl with parameters of type ThrowingRunnable Modifier and Type Method Description <SE extends Throwable,CE extends Throwable,CLE extends Throwable,V>
VAbstractTtlDecorator. getWithTtlCheckAndUpdate(SupplierWithException<TtlValue<V>,SE> getter, ThrowingConsumer<TtlValue<V>,CE> updater, ThrowingRunnable<CLE> stateClear)
<SE extends Throwable,CE extends Throwable,CLE extends Throwable,V>
TtlValue<V>AbstractTtlDecorator. getWrappedWithTtlCheckAndUpdate(SupplierWithException<TtlValue<V>,SE> getter, ThrowingConsumer<TtlValue<V>,CE> updater, ThrowingRunnable<CLE> stateClear)
-
Uses of ThrowingRunnable in org.apache.flink.streaming.runtime.operators.asyncprocessing
Methods in org.apache.flink.streaming.runtime.operators.asyncprocessing with parameters of type ThrowingRunnable Modifier and Type Method Description <K> void
AsyncStateProcessingOperator. asyncProcessWithKey(K key, ThrowingRunnable<Exception> processing)
Asynchronously process a code with a key provided.void
AsyncStateProcessingOperator. preserveRecordOrderAndProcess(ThrowingRunnable<Exception> processing)
Check the order of same-key record, and then process the record. -
Uses of ThrowingRunnable in org.apache.flink.streaming.runtime.tasks
Methods in org.apache.flink.streaming.runtime.tasks with parameters of type ThrowingRunnable Modifier and Type Method Description <E extends Throwable>
voidStreamTaskActionExecutor. runThrowing(ThrowingRunnable<E> runnable)
<E extends Throwable>
voidStreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor. runThrowing(ThrowingRunnable<E> runnable)
Deprecated. -
Uses of ThrowingRunnable in org.apache.flink.streaming.runtime.tasks.mailbox
Methods in org.apache.flink.streaming.runtime.tasks.mailbox with parameters of type ThrowingRunnable Modifier and Type Method Description void
MailboxExecutorImpl. execute(MailboxExecutor.MailOptions mailOptions, ThrowingRunnable<? extends Exception> command, String descriptionFormat, Object... descriptionArgs)
Constructors in org.apache.flink.streaming.runtime.tasks.mailbox with parameters of type ThrowingRunnable Constructor Description Mail(MailboxExecutor.MailOptions mailOptions, ThrowingRunnable<? extends Exception> runnable, int priority, StreamTaskActionExecutor actionExecutor, String descriptionFormat, Object... descriptionArgs)
Mail(ThrowingRunnable<? extends Exception> runnable, int priority, String descriptionFormat, Object... descriptionArgs)
-
Uses of ThrowingRunnable in org.apache.flink.util
Methods in org.apache.flink.util with parameters of type ThrowingRunnable Modifier and Type Method Description <E extends Exception>
OptionalConsumer<T>OptionalConsumer. ifNotPresent(ThrowingRunnable<E> r)
static <E extends Throwable>
voidLambdaUtil. withContextClassLoader(ClassLoader cl, ThrowingRunnable<E> r)
Runs the given runnable with the given ClassLoader as the thread'scontext class loader
. -
Uses of ThrowingRunnable in org.apache.flink.util.function
Subinterfaces of ThrowingRunnable in org.apache.flink.util.function Modifier and Type Interface Description interface
RunnableWithException
Similar to aRunnable
, this interface is used to capture a block of code to be executed.Classes in org.apache.flink.util.function that implement ThrowingRunnable Modifier and Type Class Description class
FutureTaskWithException<V>
FutureTask
that also implementsRunnableWithException
.Methods in org.apache.flink.util.function with parameters of type ThrowingRunnable Modifier and Type Method Description static Runnable
ThrowingRunnable. unchecked(ThrowingRunnable<?> throwingRunnable)
Converts aThrowingRunnable
into aRunnable
which throws all checked exceptions as unchecked.
-