Class SerializedJobExecutionResult

  • All Implemented Interfaces:
    Serializable

    public class SerializedJobExecutionResult
    extends Object
    implements Serializable
    A variant of the JobExecutionResult that holds its accumulator data in serialized form.
    See Also:
    Serialized Form
    • Constructor Detail

      • SerializedJobExecutionResult

        public SerializedJobExecutionResult​(org.apache.flink.api.common.JobID jobID,
                                            long netRuntime,
                                            Map<String,​org.apache.flink.util.SerializedValue<org.apache.flink.util.OptionalFailure<Object>>> accumulators)
        Creates a new SerializedJobExecutionResult.
        Parameters:
        jobID - The job's ID.
        netRuntime - The net runtime of the job (excluding pre-flight phase like the optimizer) in milliseconds
        accumulators - A map of all accumulator results produced by the job, in serialized form
    • Method Detail

      • getJobId

        public org.apache.flink.api.common.JobID getJobId()
      • getNetRuntime

        public long getNetRuntime()
      • getNetRuntime

        public long getNetRuntime​(TimeUnit desiredUnit)
        Gets the net execution time of the job, i.e., the execution time in the parallel system, without the pre-flight steps like the optimizer in a desired time unit.
        Parameters:
        desiredUnit - the unit of the NetRuntime
        Returns:
        The net execution time in the desired unit.
      • getSerializedAccumulatorResults

        public Map<String,​org.apache.flink.util.SerializedValue<org.apache.flink.util.OptionalFailure<Object>>> getSerializedAccumulatorResults()