Class TaskExecutorLocalStateStoresManager


  • public class TaskExecutorLocalStateStoresManager
    extends Object
    This class holds the all TaskLocalStateStoreImpl objects for a task executor (manager).
    • Constructor Detail

      • TaskExecutorLocalStateStoresManager

        public TaskExecutorLocalStateStoresManager​(boolean localRecoveryEnabled,
                                                   boolean localBackupEnabled,
                                                   @Nonnull
                                                   org.apache.flink.util.Reference<File[]> localStateRootDirectories,
                                                   @Nonnull
                                                   Executor discardExecutor)
                                            throws IOException
        Throws:
        IOException
    • Method Detail

      • localStateStoreForSubtask

        @Nonnull
        public TaskLocalStateStore localStateStoreForSubtask​(@Nonnull
                                                             org.apache.flink.api.common.JobID jobId,
                                                             @Nonnull
                                                             AllocationID allocationID,
                                                             @Nonnull
                                                             JobVertexID jobVertexID,
                                                             @Nonnegative
                                                             int subtaskIndex,
                                                             org.apache.flink.configuration.Configuration clusterConfiguration,
                                                             org.apache.flink.configuration.Configuration jobConfiguration)
      • releaseLocalStateForAllocationId

        public void releaseLocalStateForAllocationId​(@Nonnull
                                                     AllocationID allocationID)
      • retainLocalStateForAllocations

        public void retainLocalStateForAllocations​(Set<AllocationID> allocationsToRetain)
        Retains the given set of allocations. All other allocations will be released.
        Parameters:
        allocationsToRetain -
      • shutdown

        public void shutdown()