Class NativeFlinkService
- java.lang.Object
-
- org.apache.flink.kubernetes.operator.service.AbstractFlinkService
-
- org.apache.flink.kubernetes.operator.service.NativeFlinkService
-
- All Implemented Interfaces:
FlinkService
public class NativeFlinkService extends AbstractFlinkService
Implementation ofFlinkService
submitting and interacting with Native Kubernetes Flink clusters and jobs.
-
-
Field Summary
-
Fields inherited from class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
artifactManager, executorService, FIELD_NAME_TOTAL_CPU, FIELD_NAME_TOTAL_MEMORY, kubernetesClient, operatorConfig
-
-
Constructor Summary
Constructors Constructor Description NativeFlinkService(io.fabric8.kubernetes.client.KubernetesClient kubernetesClient, ArtifactManager artifactManager, java.util.concurrent.ExecutorService executorService, FlinkOperatorConfiguration operatorConfig, EventRecorder eventRecorder)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
cancelJob(FlinkDeployment deployment, UpgradeMode upgradeMode, org.apache.flink.configuration.Configuration configuration)
protected void
deleteClusterInternal(java.lang.String namespace, java.lang.String clusterId, org.apache.flink.configuration.Configuration conf, io.fabric8.kubernetes.api.model.DeletionPropagation deletionPropagation)
Delete Flink kubernetes cluster by deleting the kubernetes resources directly.protected void
deployApplicationCluster(JobSpec jobSpec, org.apache.flink.configuration.Configuration conf)
void
deploySessionCluster(org.apache.flink.configuration.Configuration conf)
protected io.fabric8.kubernetes.api.model.PodList
getJmPodList(java.lang.String namespace, java.lang.String clusterId)
protected io.fabric8.kubernetes.api.model.PodList
getTmPodList(java.lang.String namespace, java.lang.String clusterId)
protected java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,org.apache.flink.runtime.jobgraph.JobVertexResourceRequirements>
getVertexResources(org.apache.flink.client.program.rest.RestClusterClient<java.lang.String> client, AbstractFlinkResource<?,?> resource)
boolean
scale(FlinkResourceContext<?> ctx, org.apache.flink.configuration.Configuration deployConfig)
protected void
submitClusterInternal(org.apache.flink.configuration.Configuration conf)
protected void
updateVertexResources(org.apache.flink.client.program.rest.RestClusterClient<java.lang.String> client, AbstractFlinkResource<?,?> resource, java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,org.apache.flink.runtime.jobgraph.JobVertexResourceRequirements> newReqs)
-
Methods inherited from class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
cancelJob, cancelSessionJob, deleteBlocking, deleteClusterDeployment, deleteDeploymentBlocking, deleteHAData, disposeSavepoint, fetchCheckpointInfo, fetchSavepointInfo, getCheckpointInfo, getClusterClient, getClusterInfo, getEffectiveStatus, getJmPodList, getKubernetesClient, getLastCheckpoint, getMetrics, getRestClient, getSocketAddress, isHaMetadataAvailable, isJobManagerPortReady, listJobs, removeOperatorConfigs, requestJobResult, runJar, submitApplicationCluster, submitJobToSessionCluster, submitSessionCluster, triggerCheckpoint, triggerSavepoint, updateStatusAfterClusterDeletion, uploadJar
-
-
-
-
Constructor Detail
-
NativeFlinkService
public NativeFlinkService(io.fabric8.kubernetes.client.KubernetesClient kubernetesClient, ArtifactManager artifactManager, java.util.concurrent.ExecutorService executorService, FlinkOperatorConfiguration operatorConfig, EventRecorder eventRecorder)
-
-
Method Detail
-
deployApplicationCluster
protected void deployApplicationCluster(JobSpec jobSpec, org.apache.flink.configuration.Configuration conf) throws java.lang.Exception
- Specified by:
deployApplicationCluster
in classAbstractFlinkService
- Throws:
java.lang.Exception
-
deploySessionCluster
public void deploySessionCluster(org.apache.flink.configuration.Configuration conf) throws java.lang.Exception
- Specified by:
deploySessionCluster
in classAbstractFlinkService
- Throws:
java.lang.Exception
-
cancelJob
public void cancelJob(FlinkDeployment deployment, UpgradeMode upgradeMode, org.apache.flink.configuration.Configuration configuration) 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 classAbstractFlinkService
-
getTmPodList
protected io.fabric8.kubernetes.api.model.PodList getTmPodList(java.lang.String namespace, java.lang.String clusterId)
- Specified by:
getTmPodList
in classAbstractFlinkService
-
submitClusterInternal
protected void submitClusterInternal(org.apache.flink.configuration.Configuration conf) throws java.lang.Exception
- Throws:
java.lang.Exception
-
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 classAbstractFlinkService
- Parameters:
namespace
- NamespaceclusterId
- ClusterIdconf
- Configuration of the Flink applicationdeletionPropagation
- Resource deletion propagation policy
-
scale
public boolean scale(FlinkResourceContext<?> ctx, org.apache.flink.configuration.Configuration deployConfig) throws java.lang.Exception
- Throws:
java.lang.Exception
-
updateVertexResources
@VisibleForTesting protected void updateVertexResources(org.apache.flink.client.program.rest.RestClusterClient<java.lang.String> client, AbstractFlinkResource<?,?> resource, java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,org.apache.flink.runtime.jobgraph.JobVertexResourceRequirements> newReqs) throws java.lang.Exception
- Throws:
java.lang.Exception
-
getVertexResources
@VisibleForTesting protected java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,org.apache.flink.runtime.jobgraph.JobVertexResourceRequirements> getVertexResources(org.apache.flink.client.program.rest.RestClusterClient<java.lang.String> client, AbstractFlinkResource<?,?> resource) throws java.lang.Exception
- Throws:
java.lang.Exception
-
-