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

    • Method Summary

      All Methods Instance Methods Abstract Methods Concrete Methods 
      Modifier and Type Method Description
      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.
      boolean observe​(R resource, io.javaoperatorsdk.operator.api.reconciler.Context resourceContext, CTX ctx)
      Observe the status of the flink job.
      protected void onNoJobsFound​(R resource, org.apache.flink.configuration.Configuration config)
      Callback when no jobs were found on the cluster.
      protected abstract void onTargetJobNotFound​(R resource, org.apache.flink.configuration.Configuration config)
      Callback when no matching target job was found on a cluster where jobs were found.
      protected abstract void onTimeout​(R resource, io.javaoperatorsdk.operator.api.reconciler.Context<?> resourceContext, CTX observerContext)
      Callback when list jobs timeout.
      • Methods inherited from class java.lang.Object

        clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
    • Method Detail

      • observe

        public boolean observe​(R resource,
                               io.javaoperatorsdk.operator.api.reconciler.Context resourceContext,
                               CTX ctx)
        Observe the status of the flink job.
        Parameters:
        resource - The custom resource to be observed.
        ctx - Observe context.
        Returns:
        If job found return true, otherwise return false.
      • onTargetJobNotFound

        protected abstract void onTargetJobNotFound​(R resource,
                                                    org.apache.flink.configuration.Configuration config)
        Callback when no matching target job was found on a cluster where jobs were found.
        Parameters:
        resource - The Flink resource.
        config - Deployed/observe configuration.
      • onNoJobsFound

        protected void onNoJobsFound​(R resource,
                                     org.apache.flink.configuration.Configuration config)
        Callback when no jobs were found on the cluster.
        Parameters:
        resource - The Flink resource.
        config - Deployed/observe configuration.
      • onTimeout

        protected abstract void onTimeout​(R resource,
                                          io.javaoperatorsdk.operator.api.reconciler.Context<?> resourceContext,
                                          CTX observerContext)
        Callback when list jobs timeout.
        Parameters:
        resource - The Flink resource.
        resourceContext - Resource context.
        observerContext - Observe 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.