Modifier and Type | Method and Description |
---|---|
static void |
ClientUtils.waitUntilJobInitializationFinished(SupplierWithException<JobStatus,Exception> jobStatusSupplier,
SupplierWithException<JobResult,Exception> jobResultSupplier,
ClassLoader userCodeClassloader)
This method blocks until the job status is not INITIALIZING anymore.
|
static void |
ClientUtils.waitUntilJobInitializationFinished(SupplierWithException<JobStatus,Exception> jobStatusSupplier,
SupplierWithException<JobResult,Exception> jobResultSupplier,
ClassLoader userCodeClassloader)
This method blocks until the job status is not INITIALIZING anymore.
|
Modifier and Type | Method and Description |
---|---|
static <E> E |
Utils.doWithCleanupOnException(Closeable toCleanUp,
SupplierWithException<E,IOException> code)
Runs the given
SupplierWithException (a piece of code producing a result). |
Constructor and Description |
---|
BatchCompactCoordinator(SupplierWithException<FileSystem,IOException> fsFactory,
long compactAverageSize,
long compactTargetSize) |
BatchCompactOperator(SupplierWithException<FileSystem,IOException> fsFactory,
CompactReader.Factory<T> readerFactory,
CompactWriter.Factory<T> writerFactory) |
Modifier and Type | Method and Description |
---|---|
static <T> CompactWriter.Factory<T> |
CompactBucketWriter.factory(SupplierWithException<BucketWriter<T,String>,IOException> factory) |
Constructor and Description |
---|
CompactCoordinator(SupplierWithException<FileSystem,IOException> fsFactory,
long targetFileSize) |
CompactOperator(SupplierWithException<FileSystem,IOException> fsFactory,
CompactReader.Factory<T> readerFactory,
CompactWriter.Factory<T> writerFactory) |
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,E extends Throwable> |
ClassLoadingUtils.runWithContextClassLoader(SupplierWithException<T,E> supplier,
ClassLoader contextClassLoader)
Runs the given supplier in a
TemporaryClassLoaderContext based on the given
classloader. |
Modifier and Type | Method and Description |
---|---|
ResultPartition |
ResultPartitionFactory.create(String taskNameWithSubtaskAndId,
int partitionIndex,
ResultPartitionID id,
ResultPartitionType type,
int numberOfSubpartitions,
int maxParallelism,
boolean isBroadcast,
SupplierWithException<BufferPool,IOException> bufferPoolFactory) |
Constructor and Description |
---|
BoundedBlockingResultPartition(String owningTaskName,
int partitionIndex,
ResultPartitionID partitionId,
ResultPartitionType partitionType,
ResultSubpartition[] subpartitions,
int numTargetKeyGroups,
ResultPartitionManager partitionManager,
BufferCompressor bufferCompressor,
SupplierWithException<BufferPool,IOException> bufferPoolFactory) |
BufferWritingResultPartition(String owningTaskName,
int partitionIndex,
ResultPartitionID partitionId,
ResultPartitionType partitionType,
ResultSubpartition[] subpartitions,
int numTargetKeyGroups,
ResultPartitionManager partitionManager,
BufferCompressor bufferCompressor,
SupplierWithException<BufferPool,IOException> bufferPoolFactory) |
PipelinedResultPartition(String owningTaskName,
int partitionIndex,
ResultPartitionID partitionId,
ResultPartitionType partitionType,
ResultSubpartition[] subpartitions,
int numTargetKeyGroups,
ResultPartitionManager partitionManager,
BufferCompressor bufferCompressor,
SupplierWithException<BufferPool,IOException> bufferPoolFactory) |
ResultPartition(String owningTaskName,
int partitionIndex,
ResultPartitionID partitionId,
ResultPartitionType partitionType,
int numSubpartitions,
int numTargetKeyGroups,
ResultPartitionManager partitionManager,
BufferCompressor bufferCompressor,
SupplierWithException<BufferPool,IOException> bufferPoolFactory) |
SortMergeResultPartition(String owningTaskName,
int partitionIndex,
ResultPartitionID partitionId,
ResultPartitionType partitionType,
int numSubpartitions,
int numTargetKeyGroups,
BatchShuffleReadBufferPool readBufferPool,
Executor readIOExecutor,
ResultPartitionManager partitionManager,
String resultFileBasePath,
BufferCompressor bufferCompressor,
SupplierWithException<BufferPool,IOException> bufferPoolFactory) |
Constructor and Description |
---|
SingleInputGate(String owningTaskName,
int gateIndex,
IntermediateDataSetID consumedResultId,
ResultPartitionType consumedPartitionType,
IndexRange subpartitionIndexRange,
int numberOfInputChannels,
PartitionProducerStateProvider partitionProducerStateProvider,
SupplierWithException<BufferPool,IOException> bufferPoolFactory,
BufferDecompressor bufferDecompressor,
MemorySegmentProvider memorySegmentProvider,
int segmentSize,
ThroughputCalculator throughputCalculator,
BufferDebloater bufferDebloater,
TieredStorageConsumerClient tieredStorageConsumerClient,
TieredStorageNettyServiceImpl nettyService,
List<TieredStorageConsumerSpec> tieredStorageConsumerSpecs) |
Constructor and Description |
---|
HsResultPartition(String owningTaskName,
int partitionIndex,
ResultPartitionID partitionId,
ResultPartitionType partitionType,
int numSubpartitions,
int numTargetKeyGroups,
BatchShuffleReadBufferPool readBufferPool,
ScheduledExecutorService readIOExecutor,
ResultPartitionManager partitionManager,
String dataFileBashPath,
int networkBufferSize,
HybridShuffleConfiguration hybridShuffleConfiguration,
BufferCompressor bufferCompressor,
boolean isBroadcastOnly,
SupplierWithException<BufferPool,IOException> bufferPoolFactory) |
Modifier and Type | Method and Description |
---|---|
TieredResultPartition |
TieredResultPartitionFactory.createTieredResultPartition(String owningTaskName,
int partitionIndex,
ResultPartitionID partitionId,
ResultPartitionType partitionType,
int numSubpartitions,
int maxParallelism,
Boolean isBroadCastOnly,
ResultPartitionManager partitionManager,
BufferCompressor bufferCompressor,
SupplierWithException<BufferPool,IOException> bufferPoolFactory,
FileChannelManager fileChannelManager,
BatchShuffleReadBufferPool batchShuffleReadBufferPool,
ScheduledExecutorService batchShuffleReadIOExecutor) |
Constructor and Description |
---|
TieredResultPartition(String owningTaskName,
int partitionIndex,
ResultPartitionID partitionId,
ResultPartitionType partitionType,
int numSubpartitions,
int numTargetKeyGroups,
ResultPartitionManager partitionManager,
BufferCompressor bufferCompressor,
SupplierWithException<BufferPool,IOException> bufferPoolFactory,
TieredStorageProducerClient tieredStorageProducerClient,
TieredStorageResourceRegistry tieredStorageResourceRegistry,
TieredStorageNettyServiceImpl nettyService,
List<TieredStorageMemorySpec> tieredStorageMemorySpecs,
TieredStorageMemoryManager storageMemoryManager) |
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. |
Constructor and Description |
---|
FullSnapshotAsyncWriter(SnapshotType snapshotType,
SupplierWithException<CheckpointStreamWithResultProvider,Exception> checkpointStreamSupplier,
FullSnapshotResources<K> snapshotResources) |
Modifier and Type | Method and Description |
---|---|
<E extends Exception> |
DefaultJobTable.getOrCreateJob(JobID jobId,
SupplierWithException<? extends JobTable.JobServices,E> jobServicesSupplier) |
<E extends Exception> |
JobTable.getOrCreateJob(JobID jobId,
SupplierWithException<? extends JobTable.JobServices,E> jobServicesSupplier)
Gets a registered
JobTable.Job or creates one if not present. |
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 | 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 . |
Modifier and Type | Interface and Description |
---|---|
interface |
CheckedSupplier<R>
|
interface |
SerializableSupplierWithException<T,E extends Throwable>
A serializable
SupplierWithException . |
Modifier and Type | Method and Description |
---|---|
static <T> Supplier<T> |
FunctionUtils.uncheckedSupplier(SupplierWithException<T,?> supplierWithException)
Converts a
SupplierWithException into a Supplier which throws all checked
exceptions as unchecked. |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.