Uses of Class
org.apache.flink.runtime.rest.messages.JobPlanInfo.Plan
-
-
Uses of JobPlanInfo.Plan in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return JobPlanInfo.Plan Modifier and Type Method Description JobPlanInfo.Plan
AccessExecutionGraph. getPlan()
Returns the job plan as a JobPlanInfo.Plan.JobPlanInfo.Plan
ArchivedExecutionGraph. getPlan()
JobPlanInfo.Plan
DefaultExecutionGraph. getPlan()
Methods in org.apache.flink.runtime.executiongraph with parameters of type JobPlanInfo.Plan Modifier and Type Method Description void
DefaultExecutionGraph. setPlan(JobPlanInfo.Plan plan)
void
ExecutionGraph. setPlan(JobPlanInfo.Plan plan)
Constructors in org.apache.flink.runtime.executiongraph with parameters of type JobPlanInfo.Plan Constructor Description ArchivedExecutionGraph(org.apache.flink.api.common.JobID jobID, String jobName, Map<JobVertexID,ArchivedExecutionJobVertex> tasks, List<ArchivedExecutionJobVertex> verticesInCreationOrder, long[] stateTimestamps, org.apache.flink.api.common.JobStatus state, JobType jobType, ErrorInfo failureCause, JobPlanInfo.Plan plan, StringifiedAccumulatorResult[] archivedUserAccumulators, Map<String,org.apache.flink.util.SerializedValue<org.apache.flink.util.OptionalFailure<Object>>> serializedUserAccumulators, org.apache.flink.api.common.ArchivedExecutionConfig executionConfig, boolean isStoppable, CheckpointCoordinatorConfiguration jobCheckpointingConfiguration, CheckpointStatsSnapshot checkpointStatsSnapshot, String stateBackendName, String checkpointStorageName, org.apache.flink.util.TernaryBoolean stateChangelogEnabled, String changelogStorageName, String streamGraphJson, int pendingOperatorCount)
-
Uses of JobPlanInfo.Plan in org.apache.flink.runtime.jobgraph.jsonplan
Methods in org.apache.flink.runtime.jobgraph.jsonplan that return JobPlanInfo.Plan Modifier and Type Method Description static JobPlanInfo.Plan
JsonPlanGenerator. generatePlan(org.apache.flink.api.common.JobID jobID, String jobName, JobType jobType, Iterable<JobVertex> vertices, VertexParallelism vertexParallelism)
static JobPlanInfo.Plan
JsonPlanGenerator. generatePlan(JobGraph jg)
-
Uses of JobPlanInfo.Plan in org.apache.flink.runtime.rest.messages
Methods in org.apache.flink.runtime.rest.messages that return JobPlanInfo.Plan Modifier and Type Method Description JobPlanInfo.Plan
JobPlanInfo. getPlan()
Constructors in org.apache.flink.runtime.rest.messages with parameters of type JobPlanInfo.Plan Constructor Description JobPlanInfo(JobPlanInfo.Plan plan)
-
Uses of JobPlanInfo.Plan in org.apache.flink.runtime.rest.messages.job
Methods in org.apache.flink.runtime.rest.messages.job that return JobPlanInfo.Plan Modifier and Type Method Description JobPlanInfo.Plan
JobDetailsInfo. getPlan()
Constructors in org.apache.flink.runtime.rest.messages.job with parameters of type JobPlanInfo.Plan Constructor Description JobDetailsInfo(org.apache.flink.api.common.JobID jobId, String name, boolean isStoppable, org.apache.flink.api.common.JobStatus jobStatus, JobType jobType, long startTime, long endTime, long duration, long maxParallelism, long now, Map<org.apache.flink.api.common.JobStatus,Long> timestamps, Collection<JobDetailsInfo.JobVertexDetailsInfo> jobVertexInfos, Map<ExecutionState,Integer> jobVerticesPerState, JobPlanInfo.Plan plan, JobPlanInfo.RawJson streamGraphJson, int pendingOperators)
-