Package org.apache.flink.runtime.state
Class TaskExecutorLocalStateStoresManager
- java.lang.Object
-
- org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager
-
public class TaskExecutorLocalStateStoresManager extends Object
This class holds the allTaskLocalStateStoreImplobjects for a task executor (manager).
-
-
Field Summary
Fields Modifier and Type Field Description static StringALLOCATION_DIR_PREFIX
-
Constructor Summary
Constructors Constructor Description TaskExecutorLocalStateStoresManager(boolean localRecoveryEnabled, boolean localBackupEnabled, org.apache.flink.util.Reference<File[]> localStateRootDirectories, Executor discardExecutor)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description TaskLocalStateStorelocalStateStoreForSubtask(org.apache.flink.api.common.JobID jobId, AllocationID allocationID, JobVertexID jobVertexID, int subtaskIndex, org.apache.flink.configuration.Configuration clusterConfiguration, org.apache.flink.configuration.Configuration jobConfiguration)voidreleaseLocalStateForAllocationId(AllocationID allocationID)voidretainLocalStateForAllocations(Set<AllocationID> allocationsToRetain)Retains the given set of allocations.voidshutdown()
-
-
-
Field Detail
-
ALLOCATION_DIR_PREFIX
public static final String ALLOCATION_DIR_PREFIX
- See Also:
- Constant Field Values
-
-
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()
-
-