Uses of Class
org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson
-
Packages that use JobPlanInfo.RawJson Package Description org.apache.flink.runtime.rest.messages org.apache.flink.runtime.rest.messages.job -
-
Uses of JobPlanInfo.RawJson in org.apache.flink.runtime.rest.messages
Methods in org.apache.flink.runtime.rest.messages that return JobPlanInfo.RawJson Modifier and Type Method Description JobPlanInfo.RawJson
JobPlanInfo.RawJson.Deserializer. deserialize(org.apache.flink.shaded.jackson2.com.fasterxml.jackson.core.JsonParser jsonParser, org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.DeserializationContext deserializationContext)
Methods in org.apache.flink.runtime.rest.messages with parameters of type JobPlanInfo.RawJson Modifier and Type Method Description void
JobPlanInfo.RawJson.Serializer. serialize(JobPlanInfo.RawJson jobPlanInfo, org.apache.flink.shaded.jackson2.com.fasterxml.jackson.core.JsonGenerator jsonGenerator, org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.SerializerProvider serializerProvider)
Constructors in org.apache.flink.runtime.rest.messages with parameters of type JobPlanInfo.RawJson Constructor Description JobPlanInfo(JobPlanInfo.RawJson jsonPlan)
-
Uses of JobPlanInfo.RawJson in org.apache.flink.runtime.rest.messages.job
Constructors in org.apache.flink.runtime.rest.messages.job with parameters of type JobPlanInfo.RawJson 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.RawJson jsonPlan, JobPlanInfo.RawJson streamGraphJson, int pendingOperators)
-