Class JobStatusObserver<R extends AbstractFlinkResource<?,​?>>


  • public abstract class JobStatusObserver<R extends AbstractFlinkResource<?,​?>>
    extends java.lang.Object
    An observer to observe the job status.
    • Field Detail

      • MISSING_SESSION_JOB_ERR

        public static final java.lang.String MISSING_SESSION_JOB_ERR
        See Also:
        Constant Field Values
    • Constructor Detail

      • JobStatusObserver

        public JobStatusObserver​(EventRecorder eventRecorder)
    • Method Detail

      • observe

        public boolean observe​(FlinkResourceContext<R> ctx)
        Observe the status of the flink job.
        Parameters:
        ctx - Resource context.
        Returns:
        If job found return true, otherwise return false.
      • onTargetJobNotFound

        protected abstract void onTargetJobNotFound​(FlinkResourceContext<R> ctx)
        Callback when no matching target job was found on a cluster where jobs were found.
        Parameters:
        ctx - The Flink resource context.
      • onNoJobsFound

        protected void onNoJobsFound​(FlinkResourceContext<R> ctx)
        Callback when no jobs were found on the cluster.
        Parameters:
        ctx - The Flink resource context.
      • onTimeout

        protected abstract void onTimeout​(FlinkResourceContext<R> ctx)
        Callback when list jobs timeout.
        Parameters:
        ctx - Resource context.
      • filterTargetJob

        protected abstract java.util.Optional<org.apache.flink.runtime.client.JobStatusMessage> filterTargetJob​(JobStatus status,
                                                                                                                java.util.List<org.apache.flink.runtime.client.JobStatusMessage> clusterJobStatuses)
        Filter the target job status message by the job list from the cluster.
        Parameters:
        status - the target job status.
        clusterJobStatuses - the candidate cluster jobs.
        Returns:
        The target job status message. If no matched job found, Optional.empty() will be returned.