Package org.apache.flink.core.execution
Interface CacheSupportedPipelineExecutor
-
- All Superinterfaces:
PipelineExecutor
- All Known Implementing Classes:
AbstractSessionClusterExecutor
,KubernetesSessionClusterExecutor
,RemoteExecutor
,YarnSessionClusterExecutor
@Internal public interface CacheSupportedPipelineExecutor extends PipelineExecutor
The pipeline executor that support caching intermediate dataset.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description CompletableFuture<Void>
invalidateClusterDataset(AbstractID clusterDatasetId, Configuration configuration, ClassLoader userCodeClassloader)
Invalidate the cluster dataset with the given id.CompletableFuture<Set<AbstractID>>
listCompletedClusterDatasetIds(Configuration configuration, ClassLoader userCodeClassloader)
Return a set of ids of the completed cluster dataset.-
Methods inherited from interface org.apache.flink.core.execution.PipelineExecutor
execute
-
-
-
-
Method Detail
-
listCompletedClusterDatasetIds
CompletableFuture<Set<AbstractID>> listCompletedClusterDatasetIds(Configuration configuration, ClassLoader userCodeClassloader) throws Exception
Return a set of ids of the completed cluster dataset.- Parameters:
configuration
- theConfiguration
with the required parametersuserCodeClassloader
- theClassLoader
to deserialize usercode- Returns:
- A set of ids of the completely cached intermediate dataset.
- Throws:
Exception
-
invalidateClusterDataset
CompletableFuture<Void> invalidateClusterDataset(AbstractID clusterDatasetId, Configuration configuration, ClassLoader userCodeClassloader) throws Exception
Invalidate the cluster dataset with the given id.- Parameters:
clusterDatasetId
- id of the cluster dataset to be invalidated.configuration
- theConfiguration
with the required parametersuserCodeClassloader
- theClassLoader
to deserialize usercode- Returns:
- Future which will be completed when the cached dataset is invalidated.
- Throws:
Exception
-
-