Modifier and Type | Method and Description |
---|---|
static JobStatus |
JobStatus.valueOf(String name)
Returns the enum constant of this type with the specified name.
|
static JobStatus[] |
JobStatus.values()
Returns an array containing the constants of this enum type, in
the order they are declared.
|
Modifier and Type | Method and Description |
---|---|
static void |
ClientUtils.waitUntilJobInitializationFinished(SupplierWithException<JobStatus,Exception> jobStatusSupplier,
SupplierWithException<JobResult,Exception> jobResultSupplier,
ClassLoader userCodeClassloader)
This method blocks until the job status is not INITIALIZING anymore.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<JobStatus> |
ClusterClientJobClientAdapter.getJobStatus() |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<JobStatus> |
EmbeddedJobClient.getJobStatus() |
CompletableFuture<JobStatus> |
WebSubmissionJobClient.getJobStatus() |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<JobStatus> |
ClusterClient.getJobStatus(JobID jobId)
|
CompletableFuture<JobStatus> |
MiniClusterClient.getJobStatus(JobID jobId) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<JobStatus> |
RestClusterClient.getJobStatus(JobID jobId) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<JobStatus> |
JobClient.getJobStatus()
Requests the
JobStatus of the associated job. |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Void> |
KubernetesCheckpointIDCounter.shutdown(JobStatus jobStatus) |
Modifier and Type | Method and Description |
---|---|
Optional<JobStatus> |
EmbeddedCompletedCheckpointStore.getShutdownStatus() |
Modifier and Type | Method and Description |
---|---|
void |
CheckpointCoordinatorDeActivator.jobStatusChanges(JobID jobId,
JobStatus newJobStatus,
long timestamp) |
Checkpoint.DiscardObject |
CompletedCheckpoint.markAsDiscardedOnShutdown(JobStatus jobStatus) |
boolean |
CompletedCheckpoint.shouldBeDiscardedOnShutdown(JobStatus jobStatus) |
CompletableFuture<Void> |
StandaloneCheckpointIDCounter.shutdown(JobStatus jobStatus) |
CompletableFuture<Void> |
CheckpointIDCounter.shutdown(JobStatus jobStatus)
Shuts the
CheckpointIDCounter service. |
CompletableFuture<Void> |
ZooKeeperCheckpointIDCounter.shutdown(JobStatus jobStatus) |
CompletableFuture<Void> |
DeactivatedCheckpointIDCounter.shutdown(JobStatus jobStatus) |
void |
StandaloneCompletedCheckpointStore.shutdown(JobStatus jobStatus,
CheckpointsCleaner checkpointsCleaner) |
void |
DeactivatedCheckpointCompletedCheckpointStore.shutdown(JobStatus jobStatus,
CheckpointsCleaner checkpointsCleaner) |
void |
CompletedCheckpointStore.shutdown(JobStatus jobStatus,
CheckpointsCleaner checkpointsCleaner)
Shuts down the store.
|
void |
AbstractCompleteCheckpointStore.shutdown(JobStatus jobStatus,
CheckpointsCleaner checkpointsCleaner) |
void |
EmbeddedCompletedCheckpointStore.shutdown(JobStatus jobStatus,
CheckpointsCleaner checkpointsCleaner) |
void |
DefaultCompletedCheckpointStore.shutdown(JobStatus jobStatus,
CheckpointsCleaner checkpointsCleaner) |
Modifier and Type | Method and Description |
---|---|
JobStatus |
JobStatusMessage.getJobState() |
Constructor and Description |
---|
JobStatusMessage(JobID jobId,
String jobName,
JobStatus jobState,
long startTime) |
Modifier and Type | Method and Description |
---|---|
JobStatus |
ApplicationStatus.deriveJobStatus()
Derives the
JobStatus from the ApplicationStatus . |
Modifier and Type | Method and Description |
---|---|
static ApplicationStatus |
ApplicationStatus.fromJobStatus(JobStatus jobStatus)
Derives the ApplicationStatus that should be used for a job that resulted in the given job
status.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<JobStatus> |
Dispatcher.requestJobStatus(JobID jobId,
Time timeout) |
Modifier and Type | Method and Description |
---|---|
protected void |
Dispatcher.runPostJobGloballyTerminated(JobID jobId,
JobStatus jobStatus) |
protected void |
MiniDispatcher.runPostJobGloballyTerminated(JobID jobId,
JobStatus jobStatus) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<JobStatus> |
CheckpointResourcesCleanupRunner.requestJobStatus(Time timeout) |
Modifier and Type | Method and Description |
---|---|
JobStatus |
AccessExecutionGraph.getState()
Returns the current
JobStatus for this execution graph. |
JobStatus |
JobStatusProvider.getState()
Returns the current
JobStatus for this execution graph. |
JobStatus |
DefaultExecutionGraph.getState() |
JobStatus |
ArchivedExecutionGraph.getState() |
JobStatus |
DefaultExecutionGraph.waitUntilTerminal() |
JobStatus |
ExecutionGraph.waitUntilTerminal() |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<JobStatus> |
DefaultExecutionGraph.getTerminationFuture() |
CompletableFuture<JobStatus> |
ExecutionGraph.getTerminationFuture()
Returns the termination future of this
ExecutionGraph . |
Modifier and Type | Method and Description |
---|---|
static ArchivedExecutionGraph |
ArchivedExecutionGraph.createFrom(ExecutionGraph executionGraph,
JobStatus statusOverride)
Create a
ArchivedExecutionGraph from the given ExecutionGraph . |
static ArchivedExecutionGraph |
ArchivedExecutionGraph.createSparseArchivedExecutionGraph(JobID jobId,
String jobName,
JobStatus jobStatus,
Throwable throwable,
JobCheckpointingSettings checkpointingSettings,
long initializationTimestamp)
Create a sparse ArchivedExecutionGraph for a job.
|
long |
AccessExecutionGraph.getStatusTimestamp(JobStatus status)
Returns the timestamp for the given
JobStatus . |
long |
JobStatusProvider.getStatusTimestamp(JobStatus status)
Returns the timestamp for the given
JobStatus . |
long |
DefaultExecutionGraph.getStatusTimestamp(JobStatus status) |
long |
ArchivedExecutionGraph.getStatusTimestamp(JobStatus status) |
void |
JobStatusListener.jobStatusChanges(JobID jobId,
JobStatus newJobStatus,
long timestamp)
This method is called whenever the status of the job changes.
|
boolean |
DefaultExecutionGraph.transitionState(JobStatus current,
JobStatus newState) |
boolean |
ExecutionGraph.transitionState(JobStatus current,
JobStatus newState) |
Constructor and Description |
---|
ArchivedExecutionGraph(JobID jobID,
String jobName,
Map<JobVertexID,ArchivedExecutionJobVertex> tasks,
List<ArchivedExecutionJobVertex> verticesInCreationOrder,
long[] stateTimestamps,
JobStatus state,
ErrorInfo failureCause,
String jsonPlan,
StringifiedAccumulatorResult[] archivedUserAccumulators,
Map<String,SerializedValue<OptionalFailure<Object>>> serializedUserAccumulators,
ArchivedExecutionConfig executionConfig,
boolean isStoppable,
CheckpointCoordinatorConfiguration jobCheckpointingConfiguration,
CheckpointStatsSnapshot checkpointStatsSnapshot,
String stateBackendName,
String checkpointStorageName,
TernaryBoolean stateChangelogEnabled,
String changelogStorageName) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<JobStatus> |
JobManagerRunner.requestJobStatus(Time timeout)
Requests the current job status.
|
CompletableFuture<JobStatus> |
JobMasterServiceLeadershipRunner.requestJobStatus(Time timeout) |
CompletableFuture<JobStatus> |
JobMasterGateway.requestJobStatus(Time timeout)
Requests the current job status.
|
CompletableFuture<JobStatus> |
JobMaster.requestJobStatus(Time timeout) |
Modifier and Type | Method and Description |
---|---|
ArchivedExecutionGraph |
DefaultJobMasterServiceProcessFactory.createArchivedExecutionGraph(JobStatus jobStatus,
Throwable cause) |
ArchivedExecutionGraph |
JobMasterServiceProcessFactory.createArchivedExecutionGraph(JobStatus jobStatus,
Throwable cause)
Creates an
ArchivedExecutionGraph for the job for which this factory creates JobMasterServiceProcess with the given jobStatus and failure cause. |
Modifier and Type | Method and Description |
---|---|
JobStatus |
FlinkJobTerminatedWithoutCancellationException.getJobStatus() |
Constructor and Description |
---|
FlinkJobTerminatedWithoutCancellationException(JobID jobId,
JobStatus jobStatus) |
Modifier and Type | Method and Description |
---|---|
JobStatus |
JobIdsWithStatusOverview.JobIdWithStatus.getJobStatus() |
JobStatus |
JobStatusInfo.getJobStatus() |
JobStatus |
JobDetails.getStatus() |
Modifier and Type | Method and Description |
---|---|
static JobsOverview |
JobsOverview.create(Collection<JobStatus> allJobsStatus) |
Constructor and Description |
---|
JobDetails(JobID jobId,
String jobName,
long startTime,
long endTime,
long duration,
JobStatus status,
long lastUpdateTime,
int[] tasksPerState,
int numTasks) |
JobDetails(JobID jobId,
String jobName,
long startTime,
long endTime,
long duration,
JobStatus status,
long lastUpdateTime,
int[] tasksPerState,
int numTasks,
Map<String,Map<Integer,JobDetails.CurrentAttempts>> currentExecutionAttempts) |
JobIdWithStatus(JobID jobId,
JobStatus jobStatus) |
JobStatusInfo(JobStatus jobStatus) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<JobStatus> |
MiniClusterJobClient.getJobStatus() |
CompletableFuture<JobStatus> |
MiniCluster.getJobStatus(JobID jobId) |
Modifier and Type | Method and Description |
---|---|
void |
ResourceManager.disconnectJobManager(JobID jobId,
JobStatus jobStatus,
Exception cause) |
void |
ResourceManagerGateway.disconnectJobManager(JobID jobId,
JobStatus jobStatus,
Exception cause)
Disconnects a JobManager specified by the given resourceID from the
ResourceManager . |
Modifier and Type | Method and Description |
---|---|
JobStatus |
JobDetailsInfo.getJobStatus() |
Modifier and Type | Method and Description |
---|---|
Map<JobStatus,Long> |
JobDetailsInfo.getTimestamps() |
Constructor and Description |
---|
JobDetailsInfo(JobID jobId,
String name,
boolean isStoppable,
JobStatus jobStatus,
long startTime,
long endTime,
long duration,
long maxParallelism,
long now,
Map<JobStatus,Long> timestamps,
Collection<JobDetailsInfo.JobVertexDetailsInfo> jobVertexInfos,
Map<ExecutionState,Integer> jobVerticesPerState,
String jsonPlan) |
Constructor and Description |
---|
JobDetailsInfo(JobID jobId,
String name,
boolean isStoppable,
JobStatus jobStatus,
long startTime,
long endTime,
long duration,
long maxParallelism,
long now,
Map<JobStatus,Long> timestamps,
Collection<JobDetailsInfo.JobVertexDetailsInfo> jobVertexInfos,
Map<ExecutionState,Integer> jobVerticesPerState,
String jsonPlan) |
Modifier and Type | Method and Description |
---|---|
JobStatus |
JobStatusStore.getState() |
JobStatus |
SchedulerNG.requestJobStatus() |
JobStatus |
SchedulerBase.requestJobStatus() |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<JobStatus> |
SchedulerNG.getJobTerminationFuture() |
CompletableFuture<JobStatus> |
SchedulerBase.getJobTerminationFuture() |
Modifier and Type | Method and Description |
---|---|
long |
JobStatusStore.getStatusTimestamp(JobStatus status) |
void |
JobStatusStore.jobStatusChanges(JobID jobId,
JobStatus newJobStatus,
long timestamp) |
protected void |
SchedulerBase.transitionExecutionGraphState(JobStatus current,
JobStatus newState) |
Modifier and Type | Method and Description |
---|---|
JobStatus |
CreatingExecutionGraph.getJobStatus() |
JobStatus |
AdaptiveScheduler.requestJobStatus() |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<JobStatus> |
AdaptiveScheduler.getJobTerminationFuture() |
Modifier and Type | Method and Description |
---|---|
ArchivedExecutionGraph |
AdaptiveScheduler.getArchivedExecutionGraph(JobStatus jobStatus,
Throwable cause) |
Modifier and Type | Method and Description |
---|---|
void |
JobStatusMetrics.jobStatusChanges(JobID jobId,
JobStatus newJobStatus,
long timestamp) |
Modifier and Type | Method and Description |
---|---|
default CompletableFuture<JobStatus> |
RestfulGateway.requestJobStatus(JobID jobId,
Time timeout)
Request the
JobStatus of the given job. |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.