Class StandaloneFlinkService

    • Constructor Detail

      • StandaloneFlinkService

        public StandaloneFlinkService​(io.fabric8.kubernetes.client.KubernetesClient kubernetesClient,
                                      ArtifactManager artifactManager,
                                      java.util.concurrent.ExecutorService executorService,
                                      FlinkOperatorConfiguration operatorConfig)
    • Method Detail

      • deployApplicationCluster

        protected void deployApplicationCluster​(JobSpec jobSpec,
                                                org.apache.flink.configuration.Configuration conf)
                                         throws java.lang.Exception
        Specified by:
        deployApplicationCluster in class AbstractFlinkService
        Throws:
        java.lang.Exception
      • deploySessionCluster

        public void deploySessionCluster​(org.apache.flink.configuration.Configuration conf)
                                  throws java.lang.Exception
        Specified by:
        deploySessionCluster in class AbstractFlinkService
        Throws:
        java.lang.Exception
      • cancelJob

        public void cancelJob​(FlinkDeployment deployment,
                              UpgradeMode upgradeMode,
                              org.apache.flink.configuration.Configuration conf)
                       throws java.lang.Exception
        Throws:
        java.lang.Exception
      • getJmPodList

        protected io.fabric8.kubernetes.api.model.PodList getJmPodList​(java.lang.String namespace,
                                                                       java.lang.String clusterId)
        Specified by:
        getJmPodList in class AbstractFlinkService
      • getTmPodList

        protected io.fabric8.kubernetes.api.model.PodList getTmPodList​(java.lang.String namespace,
                                                                       java.lang.String clusterId)
        Specified by:
        getTmPodList in class AbstractFlinkService
      • createNamespacedKubeClient

        @VisibleForTesting
        protected FlinkStandaloneKubeClient createNamespacedKubeClient​(org.apache.flink.configuration.Configuration configuration)
      • submitClusterInternal

        protected void submitClusterInternal​(org.apache.flink.configuration.Configuration conf,
                                             Mode mode)
                                      throws org.apache.flink.client.deployment.ClusterDeploymentException
        Throws:
        org.apache.flink.client.deployment.ClusterDeploymentException
      • deleteClusterInternal

        protected void deleteClusterInternal​(java.lang.String namespace,
                                             java.lang.String clusterId,
                                             org.apache.flink.configuration.Configuration conf,
                                             io.fabric8.kubernetes.api.model.DeletionPropagation deletionPropagation)
        Description copied from class: AbstractFlinkService
        Delete Flink kubernetes cluster by deleting the kubernetes resources directly.
        Specified by:
        deleteClusterInternal in class AbstractFlinkService
        Parameters:
        namespace - Namespace
        clusterId - ClusterId
        conf - Configuration of the Flink application
        deletionPropagation - Resource deletion propagation policy
      • scale

        public boolean scale​(FlinkResourceContext<?> ctx,
                             org.apache.flink.configuration.Configuration deployConfig)