Modifier and Type | Method and Description |
---|---|
static void |
ClientUtils.extractAndUploadJobGraphFiles(JobGraph jobGraph,
SupplierWithException<BlobClient,IOException> clientSupplier)
Extracts all files required for the execution from the given
JobGraph and uploads them using the BlobClient
from the given Supplier . |
static void |
ClientUtils.uploadJobGraphFiles(JobGraph jobGraph,
Collection<Path> userJars,
Collection<Tuple2<String,Path>> userArtifacts,
SupplierWithException<BlobClient,IOException> clientSupplier)
Uploads the given jars and artifacts required for the execution of the given
JobGraph using the BlobClient from
the given Supplier . |
Modifier and Type | Method and Description |
---|---|
static <T> CompletableFuture<T> |
FutureUtils.supplyAsync(SupplierWithException<T,?> supplier,
Executor executor)
Returns a future which is completed with the result of the
SupplierWithException . |
Constructor and Description |
---|
SingleInputGate(String owningTaskName,
IntermediateDataSetID consumedResultId,
ResultPartitionType consumedPartitionType,
int consumedSubpartitionIndex,
int numberOfInputChannels,
PartitionProducerStateProvider partitionProducerStateProvider,
SupplierWithException<BufferPool,IOException> bufferPoolFactory,
BufferDecompressor bufferDecompressor) |
Modifier and Type | Method and Description |
---|---|
static <T> T |
HandlerRequestUtils.fromRequestBodyOrQueryParameter(T requestValue,
SupplierWithException<T,RestHandlerException> queryParameterExtractor,
T defaultValue,
org.slf4j.Logger log)
Returns
requestValue if it is not null, otherwise returns the query parameter value
if it is not null, otherwise returns the default value. |
Modifier and Type | Method and Description |
---|---|
static <R,E extends Throwable> |
LambdaUtil.withContextClassLoader(ClassLoader cl,
SupplierWithException<R,E> s)
Runs the given runnable with the given ClassLoader as the thread's
context class loader . |
Modifier and Type | Interface and Description |
---|---|
interface |
CheckedSupplier<R>
|
Modifier and Type | Method and Description |
---|---|
static <T> java.util.function.Supplier<T> |
FunctionUtils.uncheckedSupplier(SupplierWithException<T,?> supplierWithException)
Converts a
SupplierWithException into a Supplier which throws all checked exceptions
as unchecked. |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.