Uses of Interface
org.apache.flink.core.execution.JobStatusHook
-
Packages that use JobStatusHook Package Description org.apache.flink.runtime.executiongraph org.apache.flink.runtime.jobgraph org.apache.flink.streaming.api.graph org.apache.flink.table.execution -
-
Uses of JobStatusHook in org.apache.flink.runtime.executiongraph
Constructor parameters in org.apache.flink.runtime.executiongraph with type arguments of type JobStatusHook Constructor Description DefaultExecutionGraph(JobType jobType, JobInformation jobInformation, ScheduledExecutorService futureExecutor, Executor ioExecutor, Duration rpcTimeout, int executionHistorySizeLimit, ClassLoader userClassLoader, BlobWriter blobWriter, PartitionGroupReleaseStrategy.Factory partitionGroupReleaseStrategyFactory, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentListener executionDeploymentListener, ExecutionStateUpdateListener executionStateUpdateListener, long initializationTimestamp, VertexAttemptNumberStore initialAttemptCounts, VertexParallelismStore vertexParallelismStore, boolean isDynamic, ExecutionJobVertex.Factory executionJobVertexFactory, List<JobStatusHook> jobStatusHooks, MarkPartitionFinishedStrategy markPartitionFinishedStrategy, TaskDeploymentDescriptorFactory taskDeploymentDescriptorFactory, List<JobStatusChangedListener> jobStatusChangedListeners)
-
Uses of JobStatusHook in org.apache.flink.runtime.jobgraph
Methods in org.apache.flink.runtime.jobgraph that return types with arguments of type JobStatusHook Modifier and Type Method Description List<JobStatusHook>
JobGraph. getJobStatusHooks()
Method parameters in org.apache.flink.runtime.jobgraph with type arguments of type JobStatusHook Modifier and Type Method Description void
JobGraph. setJobStatusHooks(List<JobStatusHook> hooks)
-
Uses of JobStatusHook in org.apache.flink.streaming.api.graph
Methods in org.apache.flink.streaming.api.graph that return types with arguments of type JobStatusHook Modifier and Type Method Description List<JobStatusHook>
StreamGraph. getJobStatusHooks()
Methods in org.apache.flink.streaming.api.graph with parameters of type JobStatusHook Modifier and Type Method Description void
StreamGraph. registerJobStatusHook(JobStatusHook hook)
Registers the JobStatusHook. -
Uses of JobStatusHook in org.apache.flink.table.execution
Classes in org.apache.flink.table.execution that implement JobStatusHook Modifier and Type Class Description class
StagingSinkJobStatusHook
This hook is used to implement atomic semantics for CTAS(CREATE TABLE AS SELECT) or RTAS([CREATE OR] REPLACE TABLE AS SELECT) statement.
-