Modifier and Type | Method and Description |
---|---|
protected void |
CliFrontend.executeProgram(PackagedProgram program,
ClusterClient<?> client,
int parallelism) |
Modifier and Type | Method and Description |
---|---|
ClusterClient<T> |
ClusterDescriptor.deployJobCluster(ClusterSpecification clusterSpecification,
JobGraph jobGraph,
boolean detached)
Deploys a per-job cluster with the given job on the cluster.
|
ClusterClient<T> |
ClusterDescriptor.deploySessionCluster(ClusterSpecification clusterSpecification)
Triggers deployment of a cluster.
|
ClusterClient<T> |
ClusterDescriptor.retrieve(T clusterId)
Retrieves an existing Flink Cluster.
|
Modifier and Type | Class and Description |
---|---|
class |
MiniClusterClient
Client to interact with a
MiniCluster . |
class |
StandaloneClusterClient
Cluster client for communication with an standalone (on-premise) cluster or an existing cluster that has been
brought up independently of a specific job.
|
Modifier and Type | Field and Description |
---|---|
protected ClusterClient<?> |
ContextEnvironment.client |
Modifier and Type | Method and Description |
---|---|
ClusterClient<?> |
ContextEnvironment.getClient() |
Constructor and Description |
---|
ContextEnvironment(ClusterClient<?> remoteConnection,
List<URL> jarFiles,
List<URL> classpaths,
ClassLoader userCodeClassLoader,
SavepointRestoreSettings savepointSettings) |
ContextEnvironmentFactory(ClusterClient<?> client,
List<URL> jarFilesToAttach,
List<URL> classpathsToAttach,
ClassLoader userCodeClassLoader,
int defaultParallelism,
boolean isDetached,
SavepointRestoreSettings savepointSettings) |
DetachedEnvironment(ClusterClient<?> remoteConnection,
List<URL> jarFiles,
List<URL> classpaths,
ClassLoader userCodeClassLoader,
SavepointRestoreSettings savepointSettings) |
Modifier and Type | Class and Description |
---|---|
class |
RestClusterClient<T>
A
ClusterClient implementation that communicates via HTTP REST requests. |
Modifier and Type | Method and Description |
---|---|
ClusterClient<?> |
MiniClusterResource.getClusterClient() |
Modifier and Type | Class and Description |
---|---|
class |
YarnClusterClient
Java representation of a running Flink cluster within YARN.
|
Modifier and Type | Method and Description |
---|---|
protected ClusterClient<org.apache.hadoop.yarn.api.records.ApplicationId> |
YarnClusterDescriptor.createYarnClusterClient(AbstractYarnClusterDescriptor descriptor,
int numberTaskManagers,
int slotsPerTaskManager,
org.apache.hadoop.yarn.api.records.ApplicationReport report,
Configuration flinkConfiguration,
boolean perJobCluster) |
protected ClusterClient<org.apache.hadoop.yarn.api.records.ApplicationId> |
LegacyYarnClusterDescriptor.createYarnClusterClient(AbstractYarnClusterDescriptor descriptor,
int numberTaskManagers,
int slotsPerTaskManager,
org.apache.hadoop.yarn.api.records.ApplicationReport report,
Configuration flinkConfiguration,
boolean perJobCluster) |
protected abstract ClusterClient<org.apache.hadoop.yarn.api.records.ApplicationId> |
AbstractYarnClusterDescriptor.createYarnClusterClient(AbstractYarnClusterDescriptor descriptor,
int numberTaskManagers,
int slotsPerTaskManager,
org.apache.hadoop.yarn.api.records.ApplicationReport report,
Configuration flinkConfiguration,
boolean perJobCluster)
Creates a YarnClusterClient; may be overriden in tests.
|
protected ClusterClient<org.apache.hadoop.yarn.api.records.ApplicationId> |
AbstractYarnClusterDescriptor.deployInternal(ClusterSpecification clusterSpecification,
String applicationName,
String yarnClusterEntrypoint,
JobGraph jobGraph,
boolean detached)
This method will block until the ApplicationMaster/JobManager have been deployed on YARN.
|
ClusterClient<org.apache.hadoop.yarn.api.records.ApplicationId> |
YarnClusterDescriptor.deployJobCluster(ClusterSpecification clusterSpecification,
JobGraph jobGraph,
boolean detached) |
ClusterClient<org.apache.hadoop.yarn.api.records.ApplicationId> |
AbstractYarnClusterDescriptor.deploySessionCluster(ClusterSpecification clusterSpecification) |
ClusterClient<org.apache.hadoop.yarn.api.records.ApplicationId> |
AbstractYarnClusterDescriptor.retrieve(org.apache.hadoop.yarn.api.records.ApplicationId applicationId) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.