Interface ExecutionPlan
-
- All Superinterfaces:
Serializable
- All Known Implementing Classes:
JobGraph,StreamGraph
@Internal public interface ExecutionPlan extends Serializable
An interface representing a general execution plan, which can be implemented by different types of graphs such as JobGraph and StreamGraph.This interface provides methods for accessing general properties of execution plans, such as the job id and job name.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Default Methods Modifier and Type Method Description voidaddUserJarBlobKey(PermanentBlobKey permanentBlobKey)Adds a blob key corresponding to a user JAR.JobCheckpointingSettingsgetCheckpointingSettings()Gets the settings for job checkpointing.List<URL>getClasspaths()Gets the classpath required for the job.longgetInitialClientHeartbeatTimeout()Gets the initial client heartbeat timeout.org.apache.flink.configuration.ConfigurationgetJobConfiguration()Gets the job configuration.org.apache.flink.api.common.JobIDgetJobID()Gets the unique identifier of the job.JobTypegetJobType()Gets the type of the job.intgetMaximumParallelism()Gets the maximum parallelism level for the job.StringgetName()Gets the name of the job.SavepointRestoreSettingsgetSavepointRestoreSettings()Gets the settings for restoring from a savepoint.org.apache.flink.util.SerializedValue<org.apache.flink.api.common.ExecutionConfig>getSerializedExecutionConfig()Gets the serialized execution configuration.Map<String,org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry>getUserArtifacts()Gets the user artifacts associated with the job.List<PermanentBlobKey>getUserJarBlobKeys()Gets the user-defined blob keys corresponding to the JAR files.List<org.apache.flink.core.fs.Path>getUserJars()Gets the user-defined JAR files required for the job.default booleanisCheckpointingEnabled()Checks if the checkpointing was enabled.booleanisDynamic()Checks if the execution plan is dynamic.booleanisEmpty()Checks if the execution plan is empty.booleanisPartialResourceConfigured()Checks if partial resource configuration is specified.voidsetSavepointRestoreSettings(SavepointRestoreSettings savepointRestoreSettings)Sets the settings for restoring from a savepoint.voidsetUserArtifactBlobKey(String artifactName, PermanentBlobKey blobKey)Sets a user artifact blob key for a specified user artifact.voidwriteUserArtifactEntriesToConfiguration()Writes user artifact entries to the job configuration.
-
-
-
Method Detail
-
getJobID
org.apache.flink.api.common.JobID getJobID()
Gets the unique identifier of the job.- Returns:
- the job id
-
getName
String getName()
Gets the name of the job.- Returns:
- the job name
-
getJobType
JobType getJobType()
Gets the type of the job.- Returns:
- the job type
-
isDynamic
boolean isDynamic()
Checks if the execution plan is dynamic.- Returns:
- true if the execution plan is dynamic; false otherwise
-
getCheckpointingSettings
JobCheckpointingSettings getCheckpointingSettings()
Gets the settings for job checkpointing.- Returns:
- the checkpointing settings
-
isEmpty
boolean isEmpty()
Checks if the execution plan is empty.- Returns:
- true if the plan is empty; false otherwise
-
getInitialClientHeartbeatTimeout
long getInitialClientHeartbeatTimeout()
Gets the initial client heartbeat timeout.- Returns:
- the timeout duration in milliseconds
-
isPartialResourceConfigured
boolean isPartialResourceConfigured()
Checks if partial resource configuration is specified.- Returns:
- true if partial resource configuration is set; false otherwise
-
getMaximumParallelism
int getMaximumParallelism()
Gets the maximum parallelism level for the job.- Returns:
- the maximum parallelism
-
getJobConfiguration
org.apache.flink.configuration.Configuration getJobConfiguration()
Gets the job configuration.- Returns:
- the job configuration
-
getUserJars
List<org.apache.flink.core.fs.Path> getUserJars()
Gets the user-defined JAR files required for the job.- Returns:
- a list of paths to user JAR files
-
getUserJarBlobKeys
List<PermanentBlobKey> getUserJarBlobKeys()
Gets the user-defined blob keys corresponding to the JAR files.- Returns:
- a list of permanent blob keys for user JARs
-
getClasspaths
List<URL> getClasspaths()
Gets the classpath required for the job.- Returns:
- a list of classpath URLs
-
getUserArtifacts
Map<String,org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry> getUserArtifacts()
Gets the user artifacts associated with the job.- Returns:
- a map of user artifacts
-
addUserJarBlobKey
void addUserJarBlobKey(PermanentBlobKey permanentBlobKey)
Adds a blob key corresponding to a user JAR.- Parameters:
permanentBlobKey- the blob key to add
-
setUserArtifactBlobKey
void setUserArtifactBlobKey(String artifactName, PermanentBlobKey blobKey) throws IOException
Sets a user artifact blob key for a specified user artifact.- Parameters:
artifactName- the name of the user artifactblobKey- the blob key corresponding to the user artifact- Throws:
IOException- if an error occurs during the operation
-
writeUserArtifactEntriesToConfiguration
void writeUserArtifactEntriesToConfiguration()
Writes user artifact entries to the job configuration.
-
getSavepointRestoreSettings
SavepointRestoreSettings getSavepointRestoreSettings()
Gets the settings for restoring from a savepoint.- Returns:
- the savepoint restore settings
-
setSavepointRestoreSettings
void setSavepointRestoreSettings(SavepointRestoreSettings savepointRestoreSettings)
Sets the settings for restoring from a savepoint.- Parameters:
savepointRestoreSettings- the settings for savepoint restoration
-
isCheckpointingEnabled
default boolean isCheckpointingEnabled()
Checks if the checkpointing was enabled.- Returns:
- true if checkpointing enabled
-
getSerializedExecutionConfig
org.apache.flink.util.SerializedValue<org.apache.flink.api.common.ExecutionConfig> getSerializedExecutionConfig()
Gets the serialized execution configuration.- Returns:
- The serialized execution configuration object
-
-