Class DefaultResourceCleaner<T>

  • All Implemented Interfaces:
    ResourceCleaner

    public class DefaultResourceCleaner<T>
    extends Object
    implements ResourceCleaner
    DefaultResourceCleaner is the default implementation of ResourceCleaner. It will try to clean up any resource that was added. Failure will result in an individual retry of the cleanup. The overall cleanup result succeeds after all subtasks succeeded.
    • Method Detail

      • forLocallyCleanableResources

        public static DefaultResourceCleaner.Builder<LocallyCleanableResource> forLocallyCleanableResources​(org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor,
                                                                                                            Executor cleanupExecutor,
                                                                                                            org.apache.flink.util.concurrent.RetryStrategy retryStrategy)
      • cleanupAsync

        public CompletableFuture<Void> cleanupAsync​(org.apache.flink.api.common.JobID jobId)
        Description copied from interface: ResourceCleaner
        Cleans job-related data from resources asynchronously.
        Specified by:
        cleanupAsync in interface ResourceCleaner
        Parameters:
        jobId - The JobID referring to the job for which the data shall be cleaned up.
        Returns:
        the cleanup result future.