Modifier and Type | Method and Description |
---|---|
ClusterSpecification |
ClusterSpecification.ClusterSpecificationBuilder.createClusterSpecification() |
ClusterSpecification |
AbstractContainerizedClusterClientFactory.getClusterSpecification(Configuration configuration) |
ClusterSpecification |
ClusterClientFactory.getClusterSpecification(Configuration configuration)
Returns the
ClusterSpecification specified by the configuration and the command
line options. |
ClusterSpecification |
StandaloneClientFactory.getClusterSpecification(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
ClusterClientProvider<StandaloneClusterId> |
StandaloneClusterDescriptor.deployJobCluster(ClusterSpecification clusterSpecification,
JobGraph jobGraph,
boolean detached) |
ClusterClientProvider<T> |
ClusterDescriptor.deployJobCluster(ClusterSpecification clusterSpecification,
JobGraph jobGraph,
boolean detached)
Deploys a per-job cluster with the given job on the cluster.
|
ClusterClientProvider<StandaloneClusterId> |
StandaloneClusterDescriptor.deploySessionCluster(ClusterSpecification clusterSpecification) |
ClusterClientProvider<T> |
ClusterDescriptor.deploySessionCluster(ClusterSpecification clusterSpecification)
Triggers deployment of a cluster.
|
Modifier and Type | Method and Description |
---|---|
ClusterClientProvider<String> |
KubernetesClusterDescriptor.deployJobCluster(ClusterSpecification clusterSpecification,
JobGraph jobGraph,
boolean detached) |
ClusterClientProvider<String> |
KubernetesClusterDescriptor.deploySessionCluster(ClusterSpecification clusterSpecification) |
Modifier and Type | Method and Description |
---|---|
void |
FlinkKubeClient.createFlinkMasterDeployment(ClusterSpecification clusterSpec)
Create flink master deployment with replication of 1.
|
void |
Fabric8FlinkKubeClient.createFlinkMasterDeployment(ClusterSpecification clusterSpecification) |
Constructor and Description |
---|
FlinkMasterDeploymentDecorator(ClusterSpecification clusterSpecification) |
Modifier and Type | Method and Description |
---|---|
ClusterSpecification |
ExecutionContext.getClusterSpec() |
Modifier and Type | Method and Description |
---|---|
ClusterClientProvider<org.apache.hadoop.yarn.api.records.ApplicationId> |
YarnClusterDescriptor.deployJobCluster(ClusterSpecification clusterSpecification,
JobGraph jobGraph,
boolean detached) |
ClusterClientProvider<org.apache.hadoop.yarn.api.records.ApplicationId> |
YarnClusterDescriptor.deploySessionCluster(ClusterSpecification clusterSpecification) |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.