Modifier and Type | Method and Description |
---|---|
JobClient |
ExecutionEnvironment.executeAsync()
Deprecated.
Triggers the program execution asynchronously.
|
JobClient |
ExecutionEnvironment.executeAsync(String jobName)
Deprecated.
Triggers the program execution asynchronously.
|
Modifier and Type | Method and Description |
---|---|
static ScheduledExecutorService |
ClientUtils.reportHeartbeatPeriodically(JobClient jobClient,
long interval,
long timeout)
The client reports the heartbeat to the dispatcher for aliveness.
|
Modifier and Type | Class and Description |
---|---|
class |
ClusterClientJobClientAdapter<ClusterID>
An implementation of the
JobClient interface that uses a ClusterClient
underneath.. |
Modifier and Type | Class and Description |
---|---|
class |
EmbeddedJobClient
A
JobClient with the ability to also submit jobs which uses directly the DispatcherGateway . |
class |
WebSubmissionJobClient
A
JobClient that only allows asking for the job id of the job it is attached to. |
Modifier and Type | Method and Description |
---|---|
JobClient |
EmbeddedJobClientCreator.getJobClient(JobID jobId,
ClassLoader userCodeClassloader)
Creates a
JobClient that is adequate for the context in which the job is executed. |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<JobClient> |
EmbeddedExecutor.execute(Pipeline pipeline,
Configuration configuration,
ClassLoader userCodeClassloader) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<JobClient> |
AbstractJobClusterExecutor.execute(Pipeline pipeline,
Configuration configuration,
ClassLoader userCodeClassloader)
Deprecated.
|
CompletableFuture<JobClient> |
LocalExecutor.execute(Pipeline pipeline,
Configuration configuration,
ClassLoader userCodeClassloader) |
CompletableFuture<JobClient> |
AbstractSessionClusterExecutor.execute(Pipeline pipeline,
Configuration configuration,
ClassLoader userCodeClassloader) |
Modifier and Type | Method and Description |
---|---|
JobClient |
StreamPlanEnvironment.executeAsync(StreamGraph streamGraph) |
JobClient |
StreamContextEnvironment.executeAsync(StreamGraph streamGraph) |
JobClient |
ContextEnvironment.executeAsync(String jobName) |
JobClient |
OptimizerPlanEnvironment.executeAsync(String jobName) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<JobClient> |
PerJobMiniClusterFactory.submitJob(JobGraph jobGraph,
ClassLoader userCodeClassloader)
Starts a
MiniCluster and submits a job. |
Modifier and Type | Method and Description |
---|---|
void |
FlinkContainerTestEnvironment.isolateNetwork(JobClient jobClient,
Runnable afterFailAction) |
void |
FlinkContainerTestEnvironment.triggerJobManagerFailover(JobClient jobClient,
Runnable afterFailAction) |
void |
FlinkContainerTestEnvironment.triggerTaskManagerFailover(JobClient jobClient,
Runnable afterFailAction) |
Modifier and Type | Method and Description |
---|---|
void |
MiniClusterTestEnvironment.isolateNetwork(JobClient jobClient,
Runnable afterFailAction) |
void |
ClusterControllable.isolateNetwork(JobClient jobClient,
Runnable afterFailAction)
Disconnect network between Flink cluster and external system.
|
void |
MiniClusterTestEnvironment.triggerJobManagerFailover(JobClient jobClient,
Runnable afterFailAction) |
void |
ClusterControllable.triggerJobManagerFailover(JobClient jobClient,
Runnable afterFailAction)
Triggers a JobManager failover.
|
void |
MiniClusterTestEnvironment.triggerTaskManagerFailover(JobClient jobClient,
Runnable afterFailAction) |
void |
ClusterControllable.triggerTaskManagerFailover(JobClient jobClient,
Runnable afterFailAction)
Triggers TaskManager failover.
|
Modifier and Type | Method and Description |
---|---|
protected JobClient |
SourceTestSuiteBase.submitJob(StreamExecutionEnvironment env,
String jobName) |
Modifier and Type | Method and Description |
---|---|
protected CollectResultIterator<T> |
SourceTestSuiteBase.CollectIteratorBuilder.build(JobClient jobClient) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<JobClient> |
PipelineExecutor.execute(Pipeline pipeline,
Configuration configuration,
ClassLoader userCodeClassloader)
|
Modifier and Type | Method and Description |
---|---|
void |
JobListener.onJobSubmitted(JobClient jobClient,
Throwable throwable)
Callback on job submission.
|
Modifier and Type | Class and Description |
---|---|
class |
MiniClusterJobClient
A
JobClient for a MiniCluster . |
Modifier and Type | Method and Description |
---|---|
JobClient |
StreamExecutionEnvironment.executeAsync()
Triggers the program asynchronously.
|
JobClient |
StreamExecutionEnvironment.executeAsync(StreamGraph streamGraph)
Triggers the program execution asynchronously.
|
JobClient |
StreamExecutionEnvironment.executeAsync(String jobName)
Triggers the program execution asynchronously.
|
Modifier and Type | Field and Description |
---|---|
JobClient |
ClientAndIterator.client |
Modifier and Type | Method and Description |
---|---|
void |
CollectResultFetcher.setJobClient(JobClient jobClient) |
void |
CollectResultIterator.setJobClient(JobClient jobClient) |
Constructor and Description |
---|
ClientAndIterator(JobClient client,
CloseableIterator<E> iterator) |
Modifier and Type | Method and Description |
---|---|
Optional<JobClient> |
TableResult.getJobClient()
For DML and DQL statement, return the
JobClient which associates the submitted Flink
job. |
Modifier and Type | Method and Description |
---|---|
Optional<JobClient> |
TableResultImpl.getJobClient() |
Modifier and Type | Method and Description |
---|---|
TableResultImpl.Builder |
TableResultImpl.Builder.jobClient(JobClient jobClient)
Specifies job client which associates the submitted Flink job.
|
StaticResultProvider |
StaticResultProvider.setJobClient(JobClient jobClient) |
ResultProvider |
ResultProvider.setJobClient(JobClient jobClient)
Set the job client associated with the select job to retrieve the result.
|
Modifier and Type | Method and Description |
---|---|
JobClient |
Executor.executeAsync(Pipeline pipeline)
Executes the given pipeline asynchronously.
|
Modifier and Type | Method and Description |
---|---|
JobClient |
ChainingOptimizingExecutor.executeAsync(Pipeline pipeline) |
Modifier and Type | Method and Description |
---|---|
JobClient |
DefaultExecutor.executeAsync(Pipeline pipeline) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.