Modifier and Type | Method and Description |
---|---|
static JobID |
JobID.fromByteArray(byte[] bytes)
Creates a new JobID from the given byte sequence.
|
static JobID |
JobID.fromByteBuffer(ByteBuffer buf) |
static JobID |
JobID.fromHexString(String hexString)
Parses a JobID from the given string.
|
static JobID |
JobID.generate()
Creates a new (statistically) random JobID.
|
JobID |
Plan.getJobId()
Gets the ID of the job that the dataflow plan belongs to.
|
JobID |
JobSubmissionResult.getJobID()
Returns the JobID assigned to the job by the Flink runtime.
|
Modifier and Type | Method and Description |
---|---|
void |
Plan.setJobId(JobID jobId)
Sets the ID of the job that the dataflow plan belongs to.
|
Constructor and Description |
---|
JobExecutionResult(JobID jobID,
long netRuntime,
Map<String,OptionalFailure<Object>> accumulators)
Creates a new JobExecutionResult.
|
JobSubmissionResult(JobID jobID) |
Modifier and Type | Method and Description |
---|---|
JobID |
RuntimeContext.getJobId()
The ID of the current job.
|
Modifier and Type | Method and Description |
---|---|
JobID |
RuntimeUDFContext.getJobId() |
Constructor and Description |
---|
RuntimeUDFContext(TaskInfo taskInfo,
ClassLoader userCodeClassLoader,
ExecutionConfig executionConfig,
Map<String,Future<Path>> cpTasks,
Map<String,Accumulator<?,?>> accumulators,
OperatorMetricGroup metrics,
JobID jobID) |
Modifier and Type | Method and Description |
---|---|
StateChangelogStorage<?> |
FsStateChangelogStorageFactory.createStorage(JobID jobID,
Configuration configuration,
TaskManagerJobMetricGroup metricGroup,
LocalRecoveryConfig localRecoveryConfig) |
static StateChangeUploadScheduler |
StateChangeUploadScheduler.fromConfig(JobID jobID,
ReadableConfig config,
ChangelogStorageMetricGroup metricGroup,
TaskChangelogRegistry changelogRegistry,
LocalRecoveryConfig localRecoveryConfig) |
Modifier and Type | Method and Description |
---|---|
JobID |
ClusterClientJobClientAdapter.getJobID() |
Constructor and Description |
---|
ClusterClientJobClientAdapter(ClusterClientProvider<ClusterID> clusterClientProvider,
JobID jobID,
ClassLoader classLoader) |
Modifier and Type | Method and Description |
---|---|
JobID |
EmbeddedJobClient.getJobID() |
JobID |
WebSubmissionJobClient.getJobID() |
Modifier and Type | Method and Description |
---|---|
List<JobID> |
ApplicationRunner.run(DispatcherGateway dispatcherGateway,
PackagedProgram program,
Configuration configuration)
Runs the application using the provided
dispatcherGateway . |
List<JobID> |
DetachedApplicationRunner.run(DispatcherGateway dispatcherGateway,
PackagedProgram program,
Configuration configuration) |
Constructor and Description |
---|
EmbeddedJobClient(JobID jobId,
DispatcherGateway dispatcherGateway,
ScheduledExecutor retryExecutor,
Time rpcTimeout,
ClassLoader classLoader) |
UnsuccessfulExecutionException(JobID jobID,
ApplicationStatus status,
String message,
Throwable cause) |
WebSubmissionJobClient(JobID jobId) |
Constructor and Description |
---|
ApplicationDispatcherBootstrap(PackagedProgram application,
Collection<JobID> recoveredJobIds,
Configuration configuration,
DispatcherGateway dispatcherGateway,
ScheduledExecutor scheduledExecutor,
FatalErrorHandler errorHandler) |
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. |
Constructor and Description |
---|
EmbeddedExecutor(Collection<JobID> submittedJobIds,
DispatcherGateway dispatcherGateway,
EmbeddedJobClientCreator jobClientCreator)
Creates a
EmbeddedExecutor . |
EmbeddedExecutorFactory(Collection<JobID> submittedJobIds,
DispatcherGateway dispatcherGateway,
ScheduledExecutor retryExecutor)
Creates an
EmbeddedExecutorFactory . |
EmbeddedExecutorServiceLoader(Collection<JobID> submittedJobIds,
DispatcherGateway dispatcherGateway,
ScheduledExecutor retryExecutor)
Creates an
EmbeddedExecutorServiceLoader . |
WebSubmissionExecutorFactory(Collection<JobID> submittedJobIds,
DispatcherGateway dispatcherGateway)
Creates an
WebSubmissionExecutorFactory . |
WebSubmissionExecutorServiceLoader(Collection<JobID> submittedJobIds,
DispatcherGateway dispatcherGateway)
Creates an
WebSubmissionExecutorServiceLoader . |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<JobID> |
MiniClusterClient.submitJob(JobGraph jobGraph) |
CompletableFuture<JobID> |
ClusterClient.submitJob(JobGraph jobGraph)
Submit the given
JobGraph to the cluster. |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
MiniClusterClient.cancel(JobID jobId) |
CompletableFuture<Acknowledge> |
ClusterClient.cancel(JobID jobId)
Cancels a job identified by the job id.
|
CompletableFuture<String> |
MiniClusterClient.cancelWithSavepoint(JobID jobId,
String savepointDirectory,
SavepointFormatType formatType) |
CompletableFuture<String> |
ClusterClient.cancelWithSavepoint(JobID jobId,
String savepointDirectory,
SavepointFormatType formatType)
Cancels a job identified by the job id and triggers a savepoint.
|
static JobGraph |
PackagedProgramUtils.createJobGraph(PackagedProgram packagedProgram,
Configuration configuration,
int defaultParallelism,
JobID jobID,
boolean suppressOutput)
|
default CompletableFuture<Map<String,Object>> |
ClusterClient.getAccumulators(JobID jobID)
Requests and returns the accumulators for the given job identifier.
|
CompletableFuture<Map<String,Object>> |
MiniClusterClient.getAccumulators(JobID jobID,
ClassLoader loader) |
CompletableFuture<Map<String,Object>> |
ClusterClient.getAccumulators(JobID jobID,
ClassLoader loader)
Requests and returns the accumulators for the given job identifier.
|
CompletableFuture<JobStatus> |
MiniClusterClient.getJobStatus(JobID jobId) |
CompletableFuture<JobStatus> |
ClusterClient.getJobStatus(JobID jobId)
|
CompletableFuture<JobResult> |
MiniClusterClient.requestJobResult(JobID jobId) |
CompletableFuture<JobResult> |
ClusterClient.requestJobResult(JobID jobId)
|
CompletableFuture<CoordinationResponse> |
MiniClusterClient.sendCoordinationRequest(JobID jobId,
OperatorID operatorId,
CoordinationRequest request) |
CompletableFuture<CoordinationResponse> |
ClusterClient.sendCoordinationRequest(JobID jobId,
OperatorID operatorId,
CoordinationRequest request)
Sends out a request to a specified coordinator and return the response.
|
CompletableFuture<String> |
MiniClusterClient.stopWithSavepoint(JobID jobId,
boolean advanceToEndOfEventTime,
String savepointDirectory,
SavepointFormatType formatType) |
CompletableFuture<String> |
ClusterClient.stopWithSavepoint(JobID jobId,
boolean advanceToEndOfEventTime,
String savepointDirectory,
SavepointFormatType formatType)
Stops a program on Flink cluster whose job-manager is configured in this client's
configuration.
|
CompletableFuture<String> |
MiniClusterClient.triggerSavepoint(JobID jobId,
String savepointDirectory,
SavepointFormatType formatType) |
CompletableFuture<String> |
ClusterClient.triggerSavepoint(JobID jobId,
String savepointDirectory,
SavepointFormatType formatType)
Triggers a savepoint for the job identified by the job id.
|
Constructor and Description |
---|
ProgramInvocationException(String message,
JobID jobID)
Creates a ProgramInvocationException with the given message which contains job id.
|
ProgramInvocationException(String message,
JobID jobID,
Throwable cause)
Creates a ProgramInvocationException for the given exception with an additional
message which contains job id.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<JobID> |
RestClusterClient.submitJob(JobGraph jobGraph) |
Modifier and Type | Method and Description |
---|---|
JobID |
FlinkContainers.submitJob(JobSubmission job)
Submits the given job to the cluster.
|
Modifier and Type | Method and Description |
---|---|
Double |
MetricQuerier.getAggregatedMetricsByRestAPI(TestEnvironment.Endpoint endpoint,
JobID jobId,
String sourceOrSinkName,
String metricName,
String filter) |
static JobDetailsInfo |
MetricQuerier.getJobDetails(RestClient client,
TestEnvironment.Endpoint endpoint,
JobID jobId) |
AggregatedMetricsResponseBody |
MetricQuerier.getMetricList(TestEnvironment.Endpoint endpoint,
JobID jobId,
JobVertexID vertexId) |
AggregatedMetricsResponseBody |
MetricQuerier.getMetrics(TestEnvironment.Endpoint endpoint,
JobID jobId,
JobVertexID vertexId,
String filters) |
Modifier and Type | Method and Description |
---|---|
CheckpointStorageAccess |
RocksDBStateBackend.createCheckpointStorage(JobID jobId)
Deprecated.
|
<K> AbstractKeyedStateBackend<K> |
RocksDBStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry)
Deprecated.
|
<K> AbstractKeyedStateBackend<K> |
EmbeddedRocksDBStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry) |
<K> AbstractKeyedStateBackend<K> |
RocksDBStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry,
double managedMemoryFraction)
Deprecated.
|
<K> AbstractKeyedStateBackend<K> |
EmbeddedRocksDBStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry,
double managedMemoryFraction) |
Modifier and Type | Method and Description |
---|---|
JobID |
JobClient.getJobID()
Returns the
JobID that uniquely identifies the job this client is scoped to. |
JobID |
DetachedJobExecutionResult.getJobID() |
Constructor and Description |
---|
DetachedJobExecutionResult(JobID jobID) |
Modifier and Type | Method and Description |
---|---|
JobID |
KubernetesJobGraphStoreUtil.nameToJobID(String key)
Convert a key in ConfigMap to
JobID . |
Modifier and Type | Method and Description |
---|---|
CheckpointIDCounter |
KubernetesCheckpointRecoveryFactory.createCheckpointIDCounter(JobID jobID) |
CompletedCheckpointStore |
KubernetesCheckpointRecoveryFactory.createRecoveredCompletedCheckpointStore(JobID jobID,
int maxNumberOfCheckpointsToRetain,
SharedStateRegistryFactory sharedStateRegistryFactory,
Executor ioExecutor,
RestoreMode restoreMode) |
protected String |
KubernetesMultipleComponentLeaderElectionHaServices.getLeaderPathForJobManager(JobID jobID) |
void |
KubernetesMultipleComponentLeaderElectionHaServices.internalCleanupJobData(JobID jobID) |
String |
KubernetesJobGraphStoreUtil.jobIDToName(JobID jobID)
Convert a
JobID to config map key. |
Modifier and Type | Method and Description |
---|---|
static KubernetesCheckpointRecoveryFactory |
KubernetesCheckpointRecoveryFactory.withLeadershipValidation(FlinkKubeClient kubeClient,
Configuration configuration,
Executor executor,
String clusterId,
java.util.function.Function<JobID,String> function,
String lockIdentity) |
static KubernetesCheckpointRecoveryFactory |
KubernetesCheckpointRecoveryFactory.withoutLeadershipValidation(FlinkKubeClient kubeClient,
Configuration configuration,
Executor executor,
String clusterId,
java.util.function.Function<JobID,String> function) |
Modifier and Type | Method and Description |
---|---|
JobGraph |
JobGraphGenerator.compileJobGraph(OptimizedPlan program,
JobID jobId) |
Constructor and Description |
---|
AbstractPythonEnvironmentManager(PythonDependencyInfo dependencyInfo,
String[] tmpDirectories,
Map<String,String> systemEnv,
JobID jobID) |
Constructor and Description |
---|
EmbeddedPythonEnvironmentManager(PythonDependencyInfo dependencyInfo,
String[] tmpDirectories,
Map<String,String> systemEnv,
JobID jobID) |
Constructor and Description |
---|
ProcessPythonEnvironmentManager(PythonDependencyInfo dependencyInfo,
String[] tmpDirectories,
Map<String,String> systemEnv,
JobID jobID) |
Modifier and Type | Method and Description |
---|---|
<K,S extends State,V> |
QueryableStateClient.getKvState(JobID jobId,
String queryableStateName,
K key,
TypeHint<K> keyTypeHint,
StateDescriptor<S,V> stateDescriptor)
Returns a future holding the request result.
|
<K,S extends State,V> |
QueryableStateClient.getKvState(JobID jobId,
String queryableStateName,
K key,
TypeInformation<K> keyTypeInfo,
StateDescriptor<S,V> stateDescriptor)
Returns a future holding the request result.
|
Modifier and Type | Method and Description |
---|---|
KvStateLocationOracle |
KvStateClientProxyImpl.getKvStateLocationOracle(JobID jobId) |
void |
KvStateClientProxyImpl.updateKvStateLocationOracle(JobID jobId,
KvStateLocationOracle kvStateLocationOracle) |
Modifier and Type | Method and Description |
---|---|
JobID |
KvStateRequest.getJobId() |
Constructor and Description |
---|
KvStateRequest(JobID jobId,
String stateName,
int keyHashCode,
byte[] serializedKeyAndNamespace) |
Modifier and Type | Field and Description |
---|---|
protected JobID |
AccumulatorRegistry.jobID |
Modifier and Type | Method and Description |
---|---|
JobID |
AccumulatorSnapshot.getJobID() |
Constructor and Description |
---|
AccumulatorRegistry(JobID jobID,
ExecutionAttemptID taskID) |
AccumulatorSnapshot(JobID jobID,
ExecutionAttemptID executionAttemptID,
Map<String,Accumulator<?,?>> userAccumulators) |
Modifier and Type | Method and Description |
---|---|
List<Tuple2<JobID,BlobKey>> |
BlobCacheSizeTracker.checkLimit(long size)
Check the size limit and return the BLOBs to delete.
|
Modifier and Type | Method and Description |
---|---|
boolean |
VoidBlobStore.delete(JobID jobId,
BlobKey blobKey) |
boolean |
FileSystemBlobStore.delete(JobID jobId,
BlobKey blobKey) |
boolean |
BlobStore.delete(JobID jobId,
BlobKey blobKey)
Tries to delete a blob from storage.
|
boolean |
VoidBlobStore.deleteAll(JobID jobId) |
boolean |
FileSystemBlobStore.deleteAll(JobID jobId) |
boolean |
BlobStore.deleteAll(JobID jobId)
Tries to delete all blobs for the given job from storage.
|
boolean |
TransientBlobService.deleteFromCache(JobID jobId,
TransientBlobKey key)
Deletes the file associated with the provided job ID and blob key from the local cache.
|
boolean |
TransientBlobCache.deleteFromCache(JobID jobId,
TransientBlobKey key) |
boolean |
BlobServer.deleteFromCache(JobID jobId,
TransientBlobKey key)
Deletes the file associated with the blob key in the local storage of the blob server.
|
boolean |
BlobWriter.deletePermanent(JobID jobId,
PermanentBlobKey permanentBlobKey)
Delete the uploaded data with the given
JobID and PermanentBlobKey . |
boolean |
BlobServer.deletePermanent(JobID jobId,
PermanentBlobKey key)
Delete the uploaded data with the given
JobID and PermanentBlobKey . |
boolean |
VoidBlobWriter.deletePermanent(JobID jobId,
PermanentBlobKey key) |
boolean |
VoidBlobStore.get(JobID jobId,
BlobKey blobKey,
File localFile) |
boolean |
FileSystemBlobStore.get(JobID jobId,
BlobKey blobKey,
File localFile) |
boolean |
BlobView.get(JobID jobId,
BlobKey blobKey,
File localFile)
Copies a blob to a local file.
|
File |
PermanentBlobService.getFile(JobID jobId,
PermanentBlobKey key)
Returns the path to a local copy of the file associated with the provided job ID and blob
key.
|
File |
PermanentBlobCache.getFile(JobID jobId,
PermanentBlobKey key)
Returns the path to a local copy of the file associated with the provided job ID and blob
key.
|
File |
BlobServer.getFile(JobID jobId,
PermanentBlobKey key)
Returns the path to a local copy of the file associated with the provided job ID and blob
key.
|
File |
TransientBlobService.getFile(JobID jobId,
TransientBlobKey key)
Returns the path to a local copy of the file associated with the provided job ID and blob
key.
|
File |
TransientBlobCache.getFile(JobID jobId,
TransientBlobKey key) |
File |
BlobServer.getFile(JobID jobId,
TransientBlobKey key)
Retrieves the local path of a file associated with a job and a blob key.
|
protected File |
AbstractBlobCache.getFileInternal(JobID jobId,
BlobKey blobKey)
Returns local copy of the file for the BLOB with the given key.
|
protected File |
TransientBlobCache.getFileInternal(JobID jobId,
BlobKey blobKey) |
int |
PermanentBlobCache.getNumberOfReferenceHolders(JobID jobId) |
File |
PermanentBlobCache.getStorageLocation(JobID jobId,
BlobKey key)
Returns a file handle to the file associated with the given blob key on the blob server.
|
File |
TransientBlobCache.getStorageLocation(JobID jobId,
BlobKey key)
Returns a file handle to the file associated with the given blob key on the blob server.
|
File |
BlobServer.getStorageLocation(JobID jobId,
BlobKey key)
Returns a file handle to the file associated with the given blob key on the blob server.
|
CompletableFuture<Void> |
BlobServer.globalCleanupAsync(JobID jobId,
Executor executor)
Removes all BLOBs from local and HA store belonging to the given
JobID . |
CompletableFuture<Void> |
BlobServer.localCleanupAsync(JobID jobId,
Executor cleanupExecutor)
Deletes locally stored artifacts for the job represented by the given
JobID . |
boolean |
VoidBlobStore.put(File localFile,
JobID jobId,
BlobKey blobKey) |
boolean |
FileSystemBlobStore.put(File localFile,
JobID jobId,
BlobKey blobKey) |
boolean |
BlobStore.put(File localFile,
JobID jobId,
BlobKey blobKey)
Copies the local file to the blob store.
|
PermanentBlobKey |
BlobWriter.putPermanent(JobID jobId,
byte[] value)
Uploads the data of the given byte array for the given job to the BLOB server and makes it a
permanent BLOB.
|
PermanentBlobKey |
BlobServer.putPermanent(JobID jobId,
byte[] value) |
PermanentBlobKey |
VoidBlobWriter.putPermanent(JobID jobId,
byte[] value) |
PermanentBlobKey |
BlobWriter.putPermanent(JobID jobId,
InputStream inputStream)
Uploads the data from the given input stream for the given job to the BLOB server and makes
it a permanent BLOB.
|
PermanentBlobKey |
BlobServer.putPermanent(JobID jobId,
InputStream inputStream) |
PermanentBlobKey |
VoidBlobWriter.putPermanent(JobID jobId,
InputStream inputStream) |
TransientBlobKey |
TransientBlobService.putTransient(JobID jobId,
byte[] value)
Uploads the data of the given byte array for the given job to the BLOB server.
|
TransientBlobKey |
TransientBlobCache.putTransient(JobID jobId,
byte[] value) |
TransientBlobKey |
BlobServer.putTransient(JobID jobId,
byte[] value) |
TransientBlobKey |
TransientBlobService.putTransient(JobID jobId,
InputStream inputStream)
Uploads the data from the given input stream for the given job to the BLOB server.
|
TransientBlobKey |
TransientBlobCache.putTransient(JobID jobId,
InputStream inputStream) |
TransientBlobKey |
BlobServer.putTransient(JobID jobId,
InputStream inputStream) |
default byte[] |
PermanentBlobService.readFile(JobID jobId,
PermanentBlobKey key)
Returns the content of the file for the BLOB with the provided job ID the blob key.
|
byte[] |
PermanentBlobCache.readFile(JobID jobId,
PermanentBlobKey blobKey)
Returns the content of the file for the BLOB with the provided job ID the blob key.
|
void |
JobPermanentBlobService.registerJob(JobID jobId)
Register the given job.
|
void |
PermanentBlobCache.registerJob(JobID jobId)
Registers use of job-related BLOBs.
|
void |
JobPermanentBlobService.releaseJob(JobID jobId)
Release the given job.
|
void |
PermanentBlobCache.releaseJob(JobID jobId)
Unregisters use of job-related BLOBs and allow them to be released.
|
static <T> Either<SerializedValue<T>,PermanentBlobKey> |
BlobWriter.serializeAndTryOffload(T value,
JobID jobId,
BlobWriter blobWriter)
Serializes the given value and offloads it to the BlobServer if its size exceeds the minimum
offloading size of the BlobServer.
|
void |
BlobCacheSizeTracker.track(JobID jobId,
BlobKey blobKey,
long size)
Register the BLOB to the tracker.
|
static <T> Either<SerializedValue<T>,PermanentBlobKey> |
BlobWriter.tryOffload(SerializedValue<T> serializedValue,
JobID jobId,
BlobWriter blobWriter) |
void |
BlobCacheSizeTracker.untrackAll(JobID jobId)
Unregister all the tracked BLOBs related to the given job.
|
void |
BlobCacheSizeTracker.update(JobID jobId,
BlobKey blobKey)
Update the least used index for the BLOBs so that the tracker can easily find out the least
recently used BLOBs.
|
PermanentBlobKey |
BlobClient.uploadFile(JobID jobId,
Path file)
Uploads a single file to the
PermanentBlobService of the given BlobServer . |
static List<PermanentBlobKey> |
BlobClient.uploadFiles(InetSocketAddress serverAddress,
Configuration clientConfig,
JobID jobId,
List<Path> files)
Uploads the JAR files to the
PermanentBlobService of the BlobServer at the
given address with HA as configured. |
Modifier and Type | Method and Description |
---|---|
void |
BlobServer.retainJobs(Collection<JobID> jobsToRetain,
Executor ioExecutor) |
void |
BlobCacheSizeTracker.untrack(Tuple2<JobID,BlobKey> key)
Remove the BLOB from the tracker.
|
Modifier and Type | Method and Description |
---|---|
JobID |
CompletedCheckpoint.getJobId() |
JobID |
PendingCheckpoint.getJobId() |
Modifier and Type | Method and Description |
---|---|
void |
CheckpointCoordinatorGateway.acknowledgeCheckpoint(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
CheckpointMetrics checkpointMetrics,
SerializedValue<TaskStateSnapshot> subtaskState) |
CheckpointIDCounter |
PerJobCheckpointRecoveryFactory.createCheckpointIDCounter(JobID jobId) |
CheckpointIDCounter |
CheckpointRecoveryFactory.createCheckpointIDCounter(JobID jobId)
Creates a
CheckpointIDCounter instance for a job. |
CheckpointIDCounter |
StandaloneCheckpointRecoveryFactory.createCheckpointIDCounter(JobID ignored) |
CheckpointIDCounter |
ZooKeeperCheckpointRecoveryFactory.createCheckpointIDCounter(JobID jobID) |
CompletedCheckpointStore |
PerJobCheckpointRecoveryFactory.createRecoveredCompletedCheckpointStore(JobID jobId,
int maxNumberOfCheckpointsToRetain,
SharedStateRegistryFactory sharedStateRegistryFactory,
Executor ioExecutor,
RestoreMode restoreMode) |
CompletedCheckpointStore |
CheckpointRecoveryFactory.createRecoveredCompletedCheckpointStore(JobID jobId,
int maxNumberOfCheckpointsToRetain,
SharedStateRegistryFactory sharedStateRegistryFactory,
Executor ioExecutor,
RestoreMode restoreMode)
Creates a RECOVERED
CompletedCheckpointStore instance for a job. |
CompletedCheckpointStore |
StandaloneCheckpointRecoveryFactory.createRecoveredCompletedCheckpointStore(JobID jobId,
int maxNumberOfCheckpointsToRetain,
SharedStateRegistryFactory sharedStateRegistryFactory,
Executor ioExecutor,
RestoreMode restoreMode) |
CompletedCheckpointStore |
ZooKeeperCheckpointRecoveryFactory.createRecoveredCompletedCheckpointStore(JobID jobId,
int maxNumberOfCheckpointsToRetain,
SharedStateRegistryFactory sharedStateRegistryFactory,
Executor ioExecutor,
RestoreMode restoreMode) |
void |
CheckpointFailureManager.handleCheckpointException(PendingCheckpoint pendingCheckpoint,
CheckpointProperties checkpointProperties,
CheckpointException exception,
ExecutionAttemptID executionAttemptID,
JobID job,
PendingCheckpointStats pendingCheckpointStats,
CheckpointStatsTracker statsTracker)
Failures on JM:
all checkpoints - go against failure counter.
|
void |
CheckpointCoordinatorDeActivator.jobStatusChanges(JobID jobId,
JobStatus newJobStatus,
long timestamp) |
static CompletedCheckpoint |
Checkpoints.loadAndValidateCheckpoint(JobID jobId,
Map<JobVertexID,ExecutionJobVertex> tasks,
CompletedCheckpointStorageLocation location,
ClassLoader classLoader,
boolean allowNonRestoredState,
CheckpointProperties checkpointProperties) |
void |
CheckpointCoordinatorGateway.reportCheckpointMetrics(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
CheckpointMetrics checkpointMetrics) |
Modifier and Type | Method and Description |
---|---|
JobID |
JobStatusMessage.getJobId() |
JobID |
SerializedJobExecutionResult.getJobId() |
JobID |
JobExecutionException.getJobID() |
Modifier and Type | Method and Description |
---|---|
static DuplicateJobSubmissionException |
DuplicateJobSubmissionException.of(JobID jobId) |
static DuplicateJobSubmissionException |
DuplicateJobSubmissionException.ofGloballyTerminated(JobID jobId) |
Constructor and Description |
---|
JobCancellationException(JobID jobID,
String msg,
Throwable cause) |
JobExecutionException(JobID jobID,
String msg) |
JobExecutionException(JobID jobID,
String msg,
Throwable cause)
Constructs a new job execution exception.
|
JobExecutionException(JobID jobID,
Throwable cause) |
JobInitializationException(JobID jobID,
String msg,
Throwable cause) |
JobStatusMessage(JobID jobId,
String jobName,
JobStatus jobState,
long startTime) |
JobSubmissionException(JobID jobID,
String msg) |
JobSubmissionException(JobID jobID,
String msg,
Throwable cause) |
SerializedJobExecutionResult(JobID jobID,
long netRuntime,
Map<String,SerializedValue<OptionalFailure<Object>>> accumulators)
Creates a new SerializedJobExecutionResult.
|
Modifier and Type | Method and Description |
---|---|
JobID |
TaskDeploymentDescriptor.getJobId()
Returns the task's job ID.
|
Modifier and Type | Method and Description |
---|---|
void |
InputGateDeploymentDescriptor.loadBigData(PermanentBlobService blobService,
JobID jobId) |
Constructor and Description |
---|
TaskDeploymentDescriptor(JobID jobId,
TaskDeploymentDescriptor.MaybeOffloaded<JobInformation> serializedJobInformation,
TaskDeploymentDescriptor.MaybeOffloaded<TaskInformation> serializedTaskInformation,
ExecutionAttemptID executionAttemptId,
AllocationID allocationId,
JobManagerTaskRestore taskRestore,
List<ResultPartitionDeploymentDescriptor> resultPartitionDeploymentDescriptors,
List<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors) |
Modifier and Type | Method and Description |
---|---|
Collection<JobID> |
SingleJobJobGraphStore.getJobIds() |
Set<JobID> |
DefaultJobManagerRunnerRegistry.getRunningJobIds() |
Set<JobID> |
OnMainThreadJobManagerRunnerRegistry.getRunningJobIds() |
Set<JobID> |
JobManagerRunnerRegistry.getRunningJobIds()
Returns
JobID instances of registered JobManagerRunner instances. |
CompletableFuture<Collection<JobID>> |
DispatcherGateway.listJobs(Time timeout)
List the current set of submitted jobs.
|
CompletableFuture<Collection<JobID>> |
Dispatcher.listJobs(Time timeout) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Long> |
TriggerCheckpointFunction.apply(JobID jobId,
CheckpointType checkpointType,
Time timeout) |
CompletableFuture<String> |
TriggerSavepointFunction.apply(JobID jobId,
String targetDirectory,
SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Time timeout) |
CompletableFuture<Acknowledge> |
MiniDispatcher.cancelJob(JobID jobId,
Time timeout) |
CompletableFuture<Acknowledge> |
Dispatcher.cancelJob(JobID jobId,
Time timeout) |
CompletableFuture<CoordinationResponse> |
Dispatcher.deliverCoordinationRequestToCoordinator(JobID jobId,
OperatorID operatorId,
SerializedValue<CoordinationRequest> serializedRequest,
Time timeout) |
JobManagerRunner |
DefaultJobManagerRunnerRegistry.get(JobID jobId) |
ExecutionGraphInfo |
ExecutionGraphInfoStore.get(JobID jobId)
Get the
ExecutionGraphInfo for the given job id. |
JobManagerRunner |
OnMainThreadJobManagerRunnerRegistry.get(JobID jobId) |
JobManagerRunner |
JobManagerRunnerRegistry.get(JobID jobId)
Returns the
JobManagerRunner for the given JobID . |
ExecutionGraphInfo |
FileExecutionGraphInfoStore.get(JobID jobId) |
ExecutionGraphInfo |
MemoryExecutionGraphInfoStore.get(JobID jobId) |
JobDetails |
ExecutionGraphInfoStore.getAvailableJobDetails(JobID jobId)
Return the
JobDetails } for the given job. |
JobDetails |
FileExecutionGraphInfoStore.getAvailableJobDetails(JobID jobId) |
JobDetails |
MemoryExecutionGraphInfoStore.getAvailableJobDetails(JobID jobId) |
boolean |
DefaultJobManagerRunnerRegistry.isRegistered(JobID jobId) |
boolean |
OnMainThreadJobManagerRunnerRegistry.isRegistered(JobID jobId) |
boolean |
JobManagerRunnerRegistry.isRegistered(JobID jobId)
Checks whether a
JobManagerRunner is registered under the given JobID . |
CompletableFuture<Void> |
DefaultJobManagerRunnerRegistry.localCleanupAsync(JobID jobId,
Executor unusedExecutor) |
CompletableFuture<Void> |
OnMainThreadJobManagerRunnerRegistry.localCleanupAsync(JobID jobId,
Executor executor) |
CompletableFuture<Void> |
Dispatcher.onRemovedJobGraph(JobID jobId) |
JobGraph |
SingleJobJobGraphStore.recoverJobGraph(JobID jobId) |
CompletableFuture<ExecutionGraphInfo> |
Dispatcher.requestExecutionGraphInfo(JobID jobId,
Time timeout) |
CompletableFuture<JobResult> |
MiniDispatcher.requestJobResult(JobID jobId,
Time timeout) |
CompletableFuture<JobResult> |
Dispatcher.requestJobResult(JobID jobId,
Time timeout) |
CompletableFuture<JobStatus> |
Dispatcher.requestJobStatus(JobID jobId,
Time timeout) |
protected void |
MiniDispatcher.runPostJobGloballyTerminated(JobID jobId,
JobStatus jobStatus) |
protected void |
Dispatcher.runPostJobGloballyTerminated(JobID jobId,
JobStatus jobStatus) |
default CompletableFuture<String> |
DispatcherGateway.stopWithSavepointAndGetLocation(JobID jobId,
String targetDirectory,
SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Time timeout)
Stops the job with a savepoint, returning a future that completes with the savepoint location
when the savepoint is completed.
|
CompletableFuture<String> |
Dispatcher.stopWithSavepointAndGetLocation(JobID jobId,
String targetDirectory,
SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Time timeout) |
CompletableFuture<Acknowledge> |
DispatcherGateway.submitFailedJob(JobID jobId,
String jobName,
Throwable exception) |
CompletableFuture<Acknowledge> |
Dispatcher.submitFailedJob(JobID jobId,
String jobName,
Throwable exception) |
default CompletableFuture<String> |
DispatcherGateway.triggerCheckpoint(JobID jobID,
Time timeout) |
CompletableFuture<String> |
Dispatcher.triggerCheckpoint(JobID jobID,
Time timeout) |
default CompletableFuture<String> |
DispatcherGateway.triggerSavepointAndGetLocation(JobID jobId,
String targetDirectory,
SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Time timeout)
Triggers a savepoint with the given savepoint directory as a target, returning a future that
completes with the savepoint location when it is complete.
|
CompletableFuture<String> |
Dispatcher.triggerSavepointAndGetLocation(JobID jobId,
String targetDirectory,
SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Time timeout) |
JobManagerRunner |
DefaultJobManagerRunnerRegistry.unregister(JobID jobId) |
JobManagerRunner |
OnMainThreadJobManagerRunnerRegistry.unregister(JobID jobId) |
JobManagerRunner |
JobManagerRunnerRegistry.unregister(JobID jobId)
Unregistered the
JobManagerRunner with the given JobID . |
Modifier and Type | Method and Description |
---|---|
JobID |
CheckpointResourcesCleanupRunner.getJobID() |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Void> |
ResourceCleaner.cleanupAsync(JobID jobId)
Cleans job-related data from resources asynchronously.
|
CompletableFuture<Void> |
DefaultResourceCleaner.cleanupAsync(JobID jobId) |
CompletableFuture<Void> |
GloballyCleanableResource.globalCleanupAsync(JobID jobId,
Executor cleanupExecutor)
globalCleanupAsync is expected to be called from the main thread. |
CompletableFuture<Void> |
LocallyCleanableResource.localCleanupAsync(JobID jobId,
Executor cleanupExecutor)
localCleanupAsync is expected to be called from the main thread. |
Modifier and Type | Method and Description |
---|---|
void |
SessionDispatcherLeaderProcess.onAddedJobGraph(JobID jobId) |
CompletableFuture<Void> |
DefaultDispatcherGatewayService.onRemovedJobGraph(JobID jobId) |
CompletableFuture<Void> |
AbstractDispatcherLeaderProcess.DispatcherGatewayService.onRemovedJobGraph(JobID jobId) |
void |
SessionDispatcherLeaderProcess.onRemovedJobGraph(JobID jobId) |
Modifier and Type | Method and Description |
---|---|
JobID |
Environment.getJobID()
Returns the ID of the job that the task belongs to.
|
Modifier and Type | Method and Description |
---|---|
LibraryCacheManager.ClassLoaderLease |
LibraryCacheManager.registerClassLoaderLease(JobID jobId)
Registers a new class loader lease for the given jobId.
|
LibraryCacheManager.ClassLoaderLease |
BlobLibraryCacheManager.registerClassLoaderLease(JobID jobId) |
Modifier and Type | Method and Description |
---|---|
JobID |
ExecutionVertex.getJobId() |
JobID |
ExecutionJobVertex.getJobId() |
JobID |
JobInformation.getJobId() |
JobID |
DefaultExecutionGraph.getJobID() |
JobID |
InternalExecutionGraphAccessor.getJobID() |
JobID |
AccessExecutionGraph.getJobID()
Returns the
JobID for this execution graph. |
JobID |
ArchivedExecutionGraph.getJobID() |
Modifier and Type | Method and Description |
---|---|
static ArchivedExecutionGraph |
ArchivedExecutionGraph.createSparseArchivedExecutionGraph(JobID jobId,
String jobName,
JobStatus jobStatus,
Throwable throwable,
JobCheckpointingSettings checkpointingSettings,
long initializationTimestamp)
Create a sparse ArchivedExecutionGraph for a job.
|
void |
JobStatusListener.jobStatusChanges(JobID jobId,
JobStatus newJobStatus,
long timestamp)
This method is called whenever the status of the job changes.
|
void |
JobStatusHook.onCanceled(JobID jobId)
When job get canceled by users.
|
void |
JobStatusHook.onCreated(JobID jobId)
When Job becomes
JobStatus.CREATED status, it would only be called one time. |
void |
JobStatusHook.onFailed(JobID jobId,
Throwable throwable)
When job failed finally.
|
void |
JobStatusHook.onFinished(JobID jobId)
When job finished successfully.
|
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) |
JobInformation(JobID jobId,
String jobName,
SerializedValue<ExecutionConfig> serializedExecutionConfig,
Configuration jobConfiguration,
Collection<PermanentBlobKey> requiredJarFileBlobKeys,
Collection<URL> requiredClasspathURLs) |
Modifier and Type | Method and Description |
---|---|
Future<Path> |
FileCache.createTmpFile(String name,
DistributedCache.DistributedCacheEntry entry,
JobID jobID,
ExecutionAttemptID executionId)
If the file doesn't exists locally, retrieve the file from the blob-service.
|
void |
FileCache.releaseJob(JobID jobId,
ExecutionAttemptID executionId) |
Modifier and Type | Field and Description |
---|---|
static JobID |
HighAvailabilityServices.DEFAULT_JOB_ID
This JobID should be used to identify the old JobManager when using the
HighAvailabilityServices . |
Modifier and Type | Method and Description |
---|---|
JobID |
JobResultEntry.getJobId() |
Modifier and Type | Method and Description |
---|---|
LeaderElectionService |
AbstractHaServices.getJobManagerLeaderElectionService(JobID jobID) |
LeaderElectionService |
HighAvailabilityServices.getJobManagerLeaderElectionService(JobID jobID)
Gets the leader election service for the given job.
|
LeaderRetrievalService |
AbstractHaServices.getJobManagerLeaderRetriever(JobID jobID) |
LeaderRetrievalService |
HighAvailabilityServices.getJobManagerLeaderRetriever(JobID jobID)
Deprecated.
This method should only be used by the legacy code where the JobManager acts as
the master.
|
LeaderRetrievalService |
AbstractHaServices.getJobManagerLeaderRetriever(JobID jobID,
String defaultJobManagerAddress) |
LeaderRetrievalService |
HighAvailabilityServices.getJobManagerLeaderRetriever(JobID jobID,
String defaultJobManagerAddress)
Gets the leader retriever for the job JobMaster which is responsible for the given job.
|
protected abstract String |
AbstractHaServices.getLeaderPathForJobManager(JobID jobID)
Get the leader path for specific JobManager.
|
CompletableFuture<Void> |
AbstractHaServices.globalCleanupAsync(JobID jobID,
Executor executor) |
default CompletableFuture<Void> |
HighAvailabilityServices.globalCleanupAsync(JobID jobId,
Executor executor) |
boolean |
JobResultStore.hasCleanJobResultEntry(JobID jobId)
Returns whether the store already contains a
clean entry for the given JobID . |
boolean |
AbstractThreadsafeJobResultStore.hasCleanJobResultEntry(JobID jobId) |
protected abstract boolean |
AbstractThreadsafeJobResultStore.hasCleanJobResultEntryInternal(JobID jobId) |
boolean |
FileSystemJobResultStore.hasCleanJobResultEntryInternal(JobID jobId) |
boolean |
JobResultStore.hasDirtyJobResultEntry(JobID jobId)
Returns whether the store already contains a
dirty entry for the given JobID . |
boolean |
AbstractThreadsafeJobResultStore.hasDirtyJobResultEntry(JobID jobId) |
protected abstract boolean |
AbstractThreadsafeJobResultStore.hasDirtyJobResultEntryInternal(JobID jobId) |
boolean |
FileSystemJobResultStore.hasDirtyJobResultEntryInternal(JobID jobId) |
default boolean |
JobResultStore.hasJobResultEntry(JobID jobId)
Returns whether the store already contains an entry for a job.
|
boolean |
AbstractThreadsafeJobResultStore.hasJobResultEntry(JobID jobId) |
protected abstract void |
AbstractHaServices.internalCleanupJobData(JobID jobID)
Clean up the meta data in the distributed system(e.g.
|
void |
JobResultStore.markResultAsClean(JobID jobId)
Marks an existing
JobResultEntry as clean . |
void |
AbstractThreadsafeJobResultStore.markResultAsClean(JobID jobId) |
protected abstract void |
AbstractThreadsafeJobResultStore.markResultAsCleanInternal(JobID jobId) |
void |
FileSystemJobResultStore.markResultAsCleanInternal(JobID jobId) |
Modifier and Type | Method and Description |
---|---|
LeaderElectionService |
StandaloneHaServices.getJobManagerLeaderElectionService(JobID jobID) |
LeaderRetrievalService |
StandaloneHaServices.getJobManagerLeaderRetriever(JobID jobID) |
LeaderRetrievalService |
StandaloneHaServices.getJobManagerLeaderRetriever(JobID jobID,
String defaultJobManagerAddress) |
Modifier and Type | Method and Description |
---|---|
protected String |
ZooKeeperMultipleComponentLeaderElectionHaServices.getLeaderPathForJobManager(JobID jobID) |
protected void |
AbstractZooKeeperHaServices.internalCleanupJobData(JobID jobID) |
Modifier and Type | Method and Description |
---|---|
static Path |
FsJobArchivist.archiveJob(Path rootPath,
JobID jobId,
Collection<ArchivedJson> jsonToArchive)
Writes the given
AccessExecutionGraph to the FileSystem pointed to by JobManagerOptions.ARCHIVE_DIR . |
Modifier and Type | Method and Description |
---|---|
void |
TaskExecutorPartitionTracker.startTrackingPartition(JobID producingJobId,
TaskExecutorPartitionInfo partitionInfo)
Starts the tracking of the given partition for the given job.
|
void |
TaskExecutorPartitionTrackerImpl.startTrackingPartition(JobID producingJobId,
TaskExecutorPartitionInfo partitionInfo) |
void |
TaskExecutorPartitionTracker.stopTrackingAndReleaseJobPartitionsFor(JobID producingJobId)
Releases all partitions for the given job and stop the tracking of partitions that were
released.
|
void |
TaskExecutorPartitionTrackerImpl.stopTrackingAndReleaseJobPartitionsFor(JobID producingJobId) |
Constructor and Description |
---|
JobMasterPartitionTrackerImpl(JobID jobId,
ShuffleMaster<?> shuffleMaster,
PartitionTrackerFactory.TaskExecutorGatewayLookup taskExecutorGatewayLookup) |
Modifier and Type | Method and Description |
---|---|
JobID |
JobGraph.getJobID()
Returns the ID of the job.
|
Modifier and Type | Method and Description |
---|---|
static Map<String,DistributedCache.DistributedCacheEntry> |
JobGraphUtils.prepareUserArtifactEntries(Map<String,DistributedCache.DistributedCacheEntry> userArtifacts,
JobID jobId) |
JobGraphBuilder |
JobGraphBuilder.setJobId(JobID jobId) |
void |
JobGraph.setJobID(JobID jobID)
Sets the ID of the job.
|
Constructor and Description |
---|
JobGraph(JobID jobId,
String jobName)
Constructs a new job graph with the given job ID (or a random ID, if
null is passed),
the given name and the given execution configuration (see ExecutionConfig ). |
JobGraph(JobID jobId,
String jobName,
JobVertex... vertices)
Constructs a new job graph with the given name, the given
ExecutionConfig , the given
jobId or a random one if null supplied, and the given job vertices. |
Modifier and Type | Method and Description |
---|---|
static String |
JsonPlanGenerator.generatePlan(JobID jobID,
String jobName,
JobType jobType,
Iterable<JobVertex> vertices,
VertexParallelism vertexParallelism) |
Modifier and Type | Method and Description |
---|---|
JobID |
ZooKeeperJobGraphStoreUtil.nameToJobID(String name) |
JobID |
JobGraphStoreUtil.nameToJobID(String name)
Get the job id from name.
|
Modifier and Type | Method and Description |
---|---|
Collection<JobID> |
JobGraphStore.getJobIds()
Get all job ids of submitted job graphs to the submitted job graph store.
|
Collection<JobID> |
StandaloneJobGraphStore.getJobIds() |
Collection<JobID> |
DefaultJobGraphStore.getJobIds() |
Modifier and Type | Method and Description |
---|---|
default CompletableFuture<Void> |
JobGraphWriter.globalCleanupAsync(JobID jobId,
Executor executor) |
CompletableFuture<Void> |
DefaultJobGraphStore.globalCleanupAsync(JobID jobId,
Executor executor) |
String |
ZooKeeperJobGraphStoreUtil.jobIDToName(JobID jobId) |
String |
JobGraphStoreUtil.jobIDToName(JobID jobId)
Get the name in external storage from job id.
|
default CompletableFuture<Void> |
JobGraphWriter.localCleanupAsync(JobID jobId,
Executor executor) |
CompletableFuture<Void> |
DefaultJobGraphStore.localCleanupAsync(JobID jobId,
Executor executor)
Releases the locks on the specified
JobGraph . |
void |
JobGraphStore.JobGraphListener.onAddedJobGraph(JobID jobId)
Callback for
JobGraph instances added by a different JobGraphStore
instance. |
void |
DefaultJobGraphStore.onAddedJobGraph(JobID jobId) |
void |
JobGraphStore.JobGraphListener.onRemovedJobGraph(JobID jobId)
Callback for
JobGraph instances removed by a different JobGraphStore
instance. |
void |
DefaultJobGraphStore.onRemovedJobGraph(JobID jobId) |
JobGraph |
JobGraphStore.recoverJobGraph(JobID jobId)
|
JobGraph |
StandaloneJobGraphStore.recoverJobGraph(JobID jobId) |
JobGraph |
DefaultJobGraphStore.recoverJobGraph(JobID jobId) |
Modifier and Type | Method and Description |
---|---|
void |
TaskManagerGateway.notifyCheckpointAborted(ExecutionAttemptID executionAttemptID,
JobID jobId,
long checkpointId,
long latestCompletedCheckpointId,
long timestamp)
Notify the given task about a aborted checkpoint.
|
void |
TaskManagerGateway.notifyCheckpointOnComplete(ExecutionAttemptID executionAttemptID,
JobID jobId,
long completedCheckpointId,
long completedTimestamp,
long lastSubsumedCheckpointId)
Notify the given task about a completed checkpoint and the last subsumed checkpoint id if
possible.
|
void |
TaskManagerGateway.releasePartitions(JobID jobId,
Set<ResultPartitionID> partitionIds)
Batch release intermediate result partitions.
|
CompletableFuture<Acknowledge> |
TaskManagerGateway.triggerCheckpoint(ExecutionAttemptID executionAttemptID,
JobID jobId,
long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions)
Trigger for the given task a checkpoint.
|
Modifier and Type | Method and Description |
---|---|
JobID |
JobResult.getJobId() |
JobID |
AllocatedSlotReport.getJobId() |
JobID |
JobMasterServiceLeadershipRunner.getJobID() |
JobID |
JobManagerRunner.getJobID()
Get the job id of the executed job.
|
Modifier and Type | Method and Description |
---|---|
void |
JobMaster.acknowledgeCheckpoint(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
CheckpointMetrics checkpointMetrics,
SerializedValue<TaskStateSnapshot> checkpointState) |
SlotPoolService |
SlotPoolServiceSchedulerFactory.createSlotPoolService(JobID jid,
DeclarativeSlotPoolFactory declarativeSlotPoolFactory)
Creates a
SlotPoolService . |
SlotPoolService |
DefaultSlotPoolServiceSchedulerFactory.createSlotPoolService(JobID jid,
DeclarativeSlotPoolFactory declarativeSlotPoolFactory) |
JobResult.Builder |
JobResult.Builder.jobId(JobID jobId) |
void |
RpcTaskManagerGateway.notifyCheckpointAborted(ExecutionAttemptID executionAttemptID,
JobID jobId,
long checkpointId,
long latestCompletedCheckpointId,
long timestamp) |
void |
RpcTaskManagerGateway.notifyCheckpointOnComplete(ExecutionAttemptID executionAttemptID,
JobID jobId,
long completedCheckpointId,
long completedTimestamp,
long lastSubsumedCheckpointId) |
CompletableFuture<Acknowledge> |
JobMaster.notifyKvStateRegistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName,
KvStateID kvStateId,
InetSocketAddress kvStateServerAddress) |
CompletableFuture<Acknowledge> |
KvStateRegistryGateway.notifyKvStateRegistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName,
KvStateID kvStateId,
InetSocketAddress kvStateServerAddress)
Notifies that queryable state has been registered.
|
CompletableFuture<Acknowledge> |
JobMaster.notifyKvStateUnregistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName) |
CompletableFuture<Acknowledge> |
KvStateRegistryGateway.notifyKvStateUnregistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName)
Notifies that queryable state has been unregistered.
|
CompletableFuture<RegistrationResponse> |
JobMaster.registerTaskManager(JobID jobId,
TaskManagerRegistrationInformation taskManagerRegistrationInformation,
Time timeout) |
CompletableFuture<RegistrationResponse> |
JobMasterGateway.registerTaskManager(JobID jobId,
TaskManagerRegistrationInformation taskManagerRegistrationInformation,
Time timeout)
Registers the task manager at the job manager.
|
void |
RpcTaskManagerGateway.releasePartitions(JobID jobId,
Set<ResultPartitionID> partitionIds) |
void |
JobMaster.reportCheckpointMetrics(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
CheckpointMetrics checkpointMetrics) |
CompletableFuture<KvStateLocation> |
JobMaster.requestKvStateLocation(JobID jobId,
String registrationName) |
CompletableFuture<KvStateLocation> |
KvStateLocationOracle.requestKvStateLocation(JobID jobId,
String registrationName)
Requests a
KvStateLocation for the specified InternalKvState registration
name. |
CompletableFuture<Acknowledge> |
RpcTaskManagerGateway.triggerCheckpoint(ExecutionAttemptID executionAttemptID,
JobID jobId,
long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions) |
Constructor and Description |
---|
AllocatedSlotReport(JobID jobId,
Collection<AllocatedSlotInfo> allocatedSlotInfos) |
DefaultJobMasterServiceProcess(JobID jobId,
UUID leaderSessionId,
JobMasterServiceFactory jobMasterServiceFactory,
java.util.function.Function<Throwable,ArchivedExecutionGraph> failedArchivedExecutionGraphFactory) |
JobNotFinishedException(JobID jobId) |
Modifier and Type | Method and Description |
---|---|
JobID |
DefaultJobMasterServiceProcessFactory.getJobId() |
JobID |
JobMasterServiceProcessFactory.getJobId()
Gets the
JobID of the job for which this factory creates JobMasterServiceProcess . |
Constructor and Description |
---|
DefaultJobMasterServiceProcessFactory(JobID jobId,
String jobName,
JobCheckpointingSettings checkpointingSettings,
long initializationTimestamp,
JobMasterServiceFactory jobMasterServiceFactory) |
Modifier and Type | Method and Description |
---|---|
DeclarativeSlotPool |
DefaultDeclarativeSlotPoolFactory.create(JobID jobId,
java.util.function.Consumer<? super Collection<ResourceRequirement>> notifyNewResourceRequirements,
Time idleSlotTimeout,
Time rpcTimeout) |
DeclarativeSlotPool |
BlocklistDeclarativeSlotPoolFactory.create(JobID jobId,
java.util.function.Consumer<? super Collection<ResourceRequirement>> notifyNewResourceRequirements,
Time idleSlotTimeout,
Time rpcTimeout) |
DeclarativeSlotPool |
DeclarativeSlotPoolFactory.create(JobID jobId,
java.util.function.Consumer<? super Collection<ResourceRequirement>> notifyNewResourceRequirements,
Time idleSlotTimeout,
Time rpcTimeout) |
SlotPoolService |
DeclarativeSlotPoolServiceFactory.createSlotPoolService(JobID jobId,
DeclarativeSlotPoolFactory declarativeSlotPoolFactory) |
SlotPoolService |
SlotPoolServiceFactory.createSlotPoolService(JobID jobId,
DeclarativeSlotPoolFactory declarativeSlotPoolFactory) |
SlotPoolService |
DeclarativeSlotPoolBridgeServiceFactory.createSlotPoolService(JobID jobId,
DeclarativeSlotPoolFactory declarativeSlotPoolFactory) |
Constructor and Description |
---|
DeclarativeSlotPoolBridge(JobID jobId,
DeclarativeSlotPoolFactory declarativeSlotPoolFactory,
Clock clock,
Time rpcTimeout,
Time idleSlotTimeout,
Time batchSlotTimeout,
RequestSlotMatchingStrategy requestSlotMatchingStrategy) |
DeclarativeSlotPoolService(JobID jobId,
DeclarativeSlotPoolFactory declarativeSlotPoolFactory,
Clock clock,
Time idleSlotTimeout,
Time rpcTimeout) |
DefaultDeclarativeSlotPool(JobID jobId,
AllocatedSlotPool slotPool,
java.util.function.Consumer<? super Collection<ResourceRequirement>> notifyNewResourceRequirements,
Time idleSlotTimeout,
Time rpcTimeout) |
Constructor and Description |
---|
FlinkJobNotFoundException(JobID jobId) |
FlinkJobTerminatedWithoutCancellationException(JobID jobId,
JobStatus jobStatus) |
Modifier and Type | Method and Description |
---|---|
JobID |
AbstractCheckpointMessage.getJob() |
Constructor and Description |
---|
AbstractCheckpointMessage(JobID job,
ExecutionAttemptID taskExecutionId,
long checkpointId) |
AcknowledgeCheckpoint(JobID jobId,
ExecutionAttemptID taskExecutionId,
long checkpointId) |
AcknowledgeCheckpoint(JobID job,
ExecutionAttemptID taskExecutionId,
long checkpointId,
CheckpointMetrics checkpointMetrics,
TaskStateSnapshot subtaskState) |
DeclineCheckpoint(JobID job,
ExecutionAttemptID taskExecutionId,
long checkpointId,
CheckpointException checkpointException) |
Modifier and Type | Method and Description |
---|---|
JobID |
JobDetails.getJobId() |
JobID |
JobIdsWithStatusOverview.JobIdWithStatus.getJobId() |
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) |
Modifier and Type | Field and Description |
---|---|
protected JobID |
JobMetricGroup.jobId
The ID of the job represented by this metrics group.
|
Modifier and Type | Method and Description |
---|---|
JobID |
JobMetricGroup.jobId() |
Modifier and Type | Method and Description |
---|---|
TaskManagerJobMetricGroup |
TaskManagerMetricGroup.addJob(JobID jobId,
String jobName) |
JobManagerJobMetricGroup |
UnregisteredMetricGroups.UnregisteredJobManagerMetricGroup.addJob(JobID jobId,
String jobName) |
JobManagerJobMetricGroup |
JobManagerMetricGroup.addJob(JobID jobId,
String jobName) |
TaskManagerJobMetricGroup |
TaskManagerMetricGroup.getJobMetricsGroup(JobID jobId) |
CompletableFuture<Void> |
JobManagerMetricGroup.localCleanupAsync(JobID jobId,
Executor ignoredExecutor) |
void |
TaskManagerMetricGroup.removeJobMetricsGroup(JobID jobId) |
Constructor and Description |
---|
JobMetricGroup(MetricRegistry registry,
C parent,
JobID jobId,
String jobName,
String[] scope) |
TaskManagerJobMetricGroup(MetricRegistry registry,
TaskManagerMetricGroup parent,
JobID jobId,
String jobName) |
Modifier and Type | Method and Description |
---|---|
String[] |
JobManagerJobScopeFormat.formatScope(JobManagerMetricGroup parent,
JobID jid,
String jobName) |
String[] |
TaskManagerJobScopeFormat.formatScope(TaskManagerMetricGroup parent,
JobID jid,
String jobName) |
Modifier and Type | Method and Description |
---|---|
JobID |
MiniClusterJobClient.getJobID() |
Constructor and Description |
---|
MiniClusterJobClient(JobID jobID,
MiniCluster miniCluster,
ClassLoader classLoader,
MiniClusterJobClient.JobFinalizationBehavior finalizationBehaviour)
|
Modifier and Type | Method and Description |
---|---|
JobID |
DistributedRuntimeUDFContext.getJobId() |
Constructor and Description |
---|
DistributedRuntimeUDFContext(TaskInfo taskInfo,
UserCodeClassLoader userCodeClassLoader,
ExecutionConfig executionConfig,
Map<String,Future<Path>> cpTasks,
Map<String,Accumulator<?,?>> accumulators,
OperatorMetricGroup metrics,
ExternalResourceInfoProvider externalResourceInfoProvider,
JobID jobID) |
Modifier and Type | Method and Description |
---|---|
JobID |
KvStateLocation.getJobId()
Returns the JobID the KvState instances belong to.
|
Modifier and Type | Method and Description |
---|---|
TaskKvStateRegistry |
KvStateRegistry.createTaskRegistry(JobID jobId,
JobVertexID jobVertexId)
Creates a
TaskKvStateRegistry facade for the Task identified by the given
JobID and JobVertexID instance. |
KvStateLocationOracle |
KvStateClientProxy.getKvStateLocationOracle(JobID jobId)
Retrieves a future containing the currently leading key-value state location oracle.
|
void |
KvStateRegistryListener.notifyKvStateRegistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName,
KvStateID kvStateId)
Notifies the listener about a registered KvState instance.
|
void |
KvStateRegistryListener.notifyKvStateUnregistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName)
Notifies the listener about an unregistered KvState instance.
|
KvStateID |
KvStateRegistry.registerKvState(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName,
InternalKvState<?,?,?> kvState,
ClassLoader userClassLoader)
Registers the KvState instance and returns the assigned ID.
|
void |
KvStateRegistry.registerListener(JobID jobId,
KvStateRegistryListener listener)
Registers a listener with the registry.
|
void |
KvStateRegistry.unregisterKvState(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName,
KvStateID kvStateId)
Unregisters the KvState instance identified by the given KvStateID.
|
void |
KvStateRegistry.unregisterListener(JobID jobId)
Unregisters the listener with the registry.
|
void |
KvStateClientProxy.updateKvStateLocationOracle(JobID jobId,
KvStateLocationOracle kvStateLocationOracle)
Updates the active
Job Manager in case
of change. |
Constructor and Description |
---|
KvStateLocation(JobID jobId,
JobVertexID jobVertexId,
int numKeyGroups,
String registrationName)
Creates the location information.
|
KvStateLocationRegistry(JobID jobId,
Map<JobVertexID,ExecutionJobVertex> jobVertices)
Creates the registry for the job.
|
Modifier and Type | Method and Description |
---|---|
void |
DefaultJobLeaderIdService.addJob(JobID jobId) |
void |
JobLeaderIdService.addJob(JobID jobId)
Add a job to be monitored to retrieve the job leader id.
|
protected void |
ResourceManager.closeJobManagerConnection(JobID jobId,
org.apache.flink.runtime.resourcemanager.ResourceManager.ResourceRequirementHandling resourceRequirementHandling,
Exception cause)
This method should be called by the framework once it detects that a currently registered job
manager has failed.
|
boolean |
DefaultJobLeaderIdService.containsJob(JobID jobId) |
boolean |
JobLeaderIdService.containsJob(JobID jobId)
Check whether the given job is being monitored or not.
|
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 . |
CompletableFuture<JobMasterId> |
DefaultJobLeaderIdService.getLeaderId(JobID jobId) |
CompletableFuture<JobMasterId> |
JobLeaderIdService.getLeaderId(JobID jobId)
Get the leader's
JobMasterId future for the given job. |
boolean |
DefaultJobLeaderIdService.isValidTimeout(JobID jobId,
UUID timeoutId) |
boolean |
JobLeaderIdService.isValidTimeout(JobID jobId,
UUID timeoutId)
Checks whether the given timeoutId for the given jobId is valid or not.
|
protected void |
ResourceManager.jobLeaderLostLeadership(JobID jobId,
JobMasterId oldJobMasterId) |
void |
JobLeaderIdActions.jobLeaderLostLeadership(JobID jobId,
JobMasterId oldJobMasterId)
Callback when a monitored job leader lost its leadership.
|
void |
JobLeaderIdActions.notifyJobTimeout(JobID jobId,
UUID timeoutId)
Notify a job timeout.
|
CompletableFuture<RegistrationResponse> |
ResourceManager.registerJobMaster(JobMasterId jobMasterId,
ResourceID jobManagerResourceId,
String jobManagerAddress,
JobID jobId,
Time timeout) |
CompletableFuture<RegistrationResponse> |
ResourceManagerGateway.registerJobMaster(JobMasterId jobMasterId,
ResourceID jobMasterResourceId,
String jobMasterAddress,
JobID jobId,
Time timeout)
Register a
JobMaster at the resource manager. |
void |
DefaultJobLeaderIdService.removeJob(JobID jobId) |
void |
JobLeaderIdService.removeJob(JobID jobId)
Remove the given job from being monitored by the service.
|
protected void |
ResourceManager.removeJob(JobID jobId,
Exception cause) |
Modifier and Type | Method and Description |
---|---|
JobID |
JobManagerRegistration.getJobID() |
Constructor and Description |
---|
JobManagerRegistration(JobID jobID,
ResourceID jobManagerResourceID,
JobMasterGateway jobManagerGateway) |
Modifier and Type | Method and Description |
---|---|
JobID |
TaskManagerSlotInformation.getJobId() |
JobID |
FineGrainedTaskManagerSlot.getJobId() |
Modifier and Type | Method and Description |
---|---|
Map<PendingTaskManagerId,Map<JobID,ResourceCounter>> |
ResourceAllocationResult.getAllocationsOnPendingResources() |
Map<JobID,Map<InstanceID,ResourceCounter>> |
ResourceAllocationResult.getAllocationsOnRegisteredResources() |
Map<JobID,Collection<ResourceRequirement>> |
ResourceTracker.getMissingResources()
Returns a collection of
ResourceRequirements that describe which resources the
corresponding job is missing. |
Map<JobID,Collection<ResourceRequirement>> |
DefaultResourceTracker.getMissingResources() |
Map<JobID,ResourceCounter> |
FineGrainedTaskManagerTracker.getPendingAllocationsOfPendingTaskManager(PendingTaskManagerId pendingTaskManagerId) |
Set<JobID> |
ResourceAllocationResult.getUnfulfillableJobs() |
Map<JobID,ResourceCounter> |
FineGrainedTaskManagerTracker.removePendingTaskManager(PendingTaskManagerId pendingTaskManagerId) |
Modifier and Type | Method and Description |
---|---|
ResourceAllocationResult.Builder |
ResourceAllocationResult.Builder.addAllocationOnPendingResource(JobID jobId,
PendingTaskManagerId pendingTaskManagerId,
ResourceProfile resourceProfile) |
ResourceAllocationResult.Builder |
ResourceAllocationResult.Builder.addAllocationOnRegisteredResource(JobID jobId,
InstanceID instanceId,
ResourceProfile resourceProfile) |
void |
DefaultSlotTracker.addSlot(SlotID slotId,
ResourceProfile resourceProfile,
TaskExecutorConnection taskManagerConnection,
JobID assignedJob) |
ResourceAllocationResult.Builder |
ResourceAllocationResult.Builder.addUnfulfillableJob(JobID jobId) |
CompletableFuture<Void> |
SlotStatusSyncer.allocateSlot(InstanceID instanceId,
JobID jobId,
String targetAddress,
ResourceProfile resourceProfile)
Allocate a slot from the task manager.
|
CompletableFuture<Void> |
DefaultSlotStatusSyncer.allocateSlot(InstanceID instanceId,
JobID jobId,
String targetAddress,
ResourceProfile resourceProfile) |
void |
FineGrainedTaskManagerTracker.clearPendingAllocationsOfJob(JobID jobId) |
void |
SlotManager.clearResourceRequirements(JobID jobId)
Notifies the slot manager that the resource requirements for the given job should be cleared.
|
void |
DeclarativeSlotManager.clearResourceRequirements(JobID jobId) |
void |
FineGrainedSlotManager.clearResourceRequirements(JobID jobId) |
Collection<ResourceRequirement> |
ResourceTracker.getAcquiredResources(JobID jobId)
Returns a collection of
ResourceRequirement s that describe which resources have been
assigned to a job. |
Collection<ResourceRequirement> |
DefaultResourceTracker.getAcquiredResources(JobID jobId) |
Collection<TaskExecutorConnection> |
DefaultSlotTracker.getTaskExecutorsWithAllocatedSlotsForJob(JobID jobId) |
boolean |
ResourceTracker.isRequirementEmpty(JobID jobId)
Returns whether the
ResourceRequirement of the given job is empty. |
boolean |
DefaultResourceTracker.isRequirementEmpty(JobID jobId) |
void |
ResourceTracker.notifyAcquiredResource(JobID jobId,
ResourceProfile resourceProfile)
Notifies the tracker about the acquisition of a resource with the given resource profile, for
the given job.
|
void |
DefaultResourceTracker.notifyAcquiredResource(JobID jobId,
ResourceProfile resourceProfile) |
void |
DefaultSlotTracker.notifyAllocationComplete(SlotID slotId,
JobID jobId) |
void |
ResourceActions.notifyAllocationFailure(JobID jobId,
AllocationID allocationId,
Exception cause)
Notifies that an allocation failure has occurred.
|
void |
DefaultSlotTracker.notifyAllocationStart(SlotID slotId,
JobID jobId) |
void |
ResourceTracker.notifyLostResource(JobID jobId,
ResourceProfile resourceProfile)
Notifies the tracker about the loss of a resource with the given resource profile, for the
given job.
|
void |
DefaultResourceTracker.notifyLostResource(JobID jobId,
ResourceProfile resourceProfile) |
void |
ResourceActions.notifyNotEnoughResourcesAvailable(JobID jobId,
Collection<ResourceRequirement> acquiredResources)
Notifies that not enough resources are available to fulfill the resource requirements of a
job.
|
void |
ResourceTracker.notifyResourceRequirements(JobID jobId,
Collection<ResourceRequirement> resourceRequirements)
Notifies the tracker about a new or updated
ResourceRequirements . |
void |
DefaultResourceTracker.notifyResourceRequirements(JobID jobId,
Collection<ResourceRequirement> resourceRequirements) |
void |
FineGrainedTaskManagerTracker.notifySlotStatus(AllocationID allocationId,
JobID jobId,
InstanceID instanceId,
ResourceProfile resourceProfile,
org.apache.flink.runtime.resourcemanager.slotmanager.SlotState slotState) |
Modifier and Type | Method and Description |
---|---|
void |
FineGrainedTaskManagerTracker.replaceAllPendingAllocations(Map<PendingTaskManagerId,Map<JobID,ResourceCounter>> pendingSlotAllocations) |
ResourceAllocationResult |
ResourceAllocationStrategy.tryFulfillRequirements(Map<JobID,Collection<ResourceRequirement>> missingResources,
org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerResourceInfoProvider taskManagerResourceInfoProvider,
BlockedTaskManagerChecker blockedTaskManagerChecker)
Try to make an allocation decision to fulfill the resource requirements.
|
ResourceAllocationResult |
DefaultResourceAllocationStrategy.tryFulfillRequirements(Map<JobID,Collection<ResourceRequirement>> missingResources,
org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerResourceInfoProvider taskManagerResourceInfoProvider,
BlockedTaskManagerChecker blockedTaskManagerChecker) |
Constructor and Description |
---|
FineGrainedTaskManagerSlot(AllocationID allocationId,
JobID jobId,
ResourceProfile resourceProfile,
TaskExecutorConnection taskManagerConnection,
org.apache.flink.runtime.resourcemanager.slotmanager.SlotState slotState) |
Modifier and Type | Method and Description |
---|---|
JobID |
AsynchronousJobOperationKey.getJobId()
Get the job id for the given operation key.
|
Modifier and Type | Method and Description |
---|---|
static AsynchronousJobOperationKey |
AsynchronousJobOperationKey.of(TriggerId triggerId,
JobID jobId) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<ExecutionGraphInfo> |
ExecutionGraphCache.getExecutionGraphInfo(JobID jobId,
RestfulGateway restfulGateway)
Gets the
ExecutionGraphInfo for the given JobID and caches it. |
CompletableFuture<ExecutionGraphInfo> |
DefaultExecutionGraphCache.getExecutionGraphInfo(JobID jobId,
RestfulGateway restfulGateway) |
Modifier and Type | Method and Description |
---|---|
protected JobID |
JobIDPathParameter.convertFromString(String value) |
JobID |
JobConfigInfo.getJobId() |
Modifier and Type | Method and Description |
---|---|
protected String |
JobIDPathParameter.convertToString(JobID value) |
JobCancellationMessageParameters |
JobCancellationMessageParameters.resolveJobId(JobID jobId) |
Constructor and Description |
---|
JobConfigInfo(JobID jobId,
String jobName,
JobConfigInfo.ExecutionConfigInfo executionConfigInfo) |
Modifier and Type | Method and Description |
---|---|
JobID |
JobDetailsInfo.getJobId() |
Modifier and Type | Method and Description |
---|---|
static SubtaskExecutionAttemptDetailsInfo |
SubtaskExecutionAttemptDetailsInfo.create(AccessExecution execution,
MetricFetcher metricFetcher,
JobID jobID,
JobVertexID jobVertexID,
List<SubtaskExecutionAttemptDetailsInfo> otherConcurrentAttempts) |
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 |
---|---|
JobID |
JobsFilterQueryParameter.convertStringToValue(String value) |
Modifier and Type | Method and Description |
---|---|
String |
JobsFilterQueryParameter.convertValueToString(JobID value) |
Modifier and Type | Method and Description |
---|---|
JobID |
JobIDDeserializer.deserialize(org.apache.flink.shaded.jackson2.com.fasterxml.jackson.core.JsonParser p,
org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.DeserializationContext ctxt) |
Modifier and Type | Method and Description |
---|---|
void |
JobIDSerializer.serialize(JobID value,
org.apache.flink.shaded.jackson2.com.fasterxml.jackson.core.JsonGenerator gen,
org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.SerializerProvider provider) |
Modifier and Type | Method and Description |
---|---|
JobID |
SlotInfo.getJobId() |
Constructor and Description |
---|
SlotInfo(JobID jobId,
ResourceProfile resource) |
SlotInfo(JobID jobId,
ResourceProfileInfo resource) |
Modifier and Type | Method and Description |
---|---|
JobID |
ExecutionGraphInfo.getJobId() |
Modifier and Type | Method and Description |
---|---|
void |
SchedulerNG.acknowledgeCheckpoint(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
CheckpointMetrics checkpointMetrics,
TaskStateSnapshot checkpointState) |
void |
ExecutionGraphHandler.acknowledgeCheckpoint(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
CheckpointMetrics checkpointMetrics,
TaskStateSnapshot checkpointState) |
void |
SchedulerBase.acknowledgeCheckpoint(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
CheckpointMetrics checkpointMetrics,
TaskStateSnapshot checkpointState) |
void |
JobStatusStore.jobStatusChanges(JobID jobId,
JobStatus newJobStatus,
long timestamp) |
void |
SchedulerNG.notifyKvStateRegistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName,
KvStateID kvStateId,
InetSocketAddress kvStateServerAddress) |
void |
KvStateHandler.notifyKvStateRegistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName,
KvStateID kvStateId,
InetSocketAddress kvStateServerAddress) |
void |
SchedulerBase.notifyKvStateRegistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName,
KvStateID kvStateId,
InetSocketAddress kvStateServerAddress) |
void |
SchedulerNG.notifyKvStateUnregistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName) |
void |
KvStateHandler.notifyKvStateUnregistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName) |
void |
SchedulerBase.notifyKvStateUnregistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName) |
void |
SchedulerNG.reportCheckpointMetrics(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
CheckpointMetrics checkpointMetrics) |
void |
SchedulerBase.reportCheckpointMetrics(JobID jobID,
ExecutionAttemptID attemptId,
long id,
CheckpointMetrics metrics) |
KvStateLocation |
SchedulerNG.requestKvStateLocation(JobID jobId,
String registrationName) |
KvStateLocation |
KvStateHandler.requestKvStateLocation(JobID jobId,
String registrationName) |
KvStateLocation |
SchedulerBase.requestKvStateLocation(JobID jobId,
String registrationName) |
Modifier and Type | Method and Description |
---|---|
JobID |
JobGraphJobInformation.getJobID() |
Modifier and Type | Method and Description |
---|---|
void |
AdaptiveScheduler.acknowledgeCheckpoint(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
CheckpointMetrics checkpointMetrics,
TaskStateSnapshot checkpointState) |
void |
AdaptiveScheduler.notifyKvStateRegistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName,
KvStateID kvStateId,
InetSocketAddress kvStateServerAddress) |
void |
AdaptiveScheduler.notifyKvStateUnregistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName) |
void |
AdaptiveScheduler.reportCheckpointMetrics(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
CheckpointMetrics checkpointMetrics) |
KvStateLocation |
AdaptiveScheduler.requestKvStateLocation(JobID jobId,
String registrationName) |
Modifier and Type | Method and Description |
---|---|
void |
JobStatusMetrics.jobStatusChanges(JobID jobId,
JobStatus newJobStatus,
long timestamp) |
Modifier and Type | Method and Description |
---|---|
static void |
StopWithSavepointTerminationManager.checkSavepointActionPreconditions(CheckpointCoordinator checkpointCoordinator,
String targetDirectory,
JobID jobId,
org.slf4j.Logger logger) |
Constructor and Description |
---|
StopWithSavepointStoppingException(String savepointPath,
JobID jobID) |
StopWithSavepointStoppingException(String savepointPath,
JobID jobID,
Throwable cause) |
StopWithSavepointTerminationHandlerImpl(JobID jobId,
S schedulerWithCheckpointing,
org.slf4j.Logger log) |
Modifier and Type | Method and Description |
---|---|
JobID |
JobShuffleContextImpl.getJobId() |
JobID |
JobShuffleContext.getJobId() |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<NettyShuffleDescriptor> |
NettyShuffleMaster.registerPartitionWithProducer(JobID jobID,
PartitionDescriptor partitionDescriptor,
ProducerDescriptor producerDescriptor) |
CompletableFuture<T> |
ShuffleMaster.registerPartitionWithProducer(JobID jobID,
PartitionDescriptor partitionDescriptor,
ProducerDescriptor producerDescriptor)
Asynchronously register a partition and its producer with the shuffle service.
|
default void |
ShuffleMaster.unregisterJob(JobID jobID)
Unregisters the target job from this shuffle master, which means the corresponding job has
reached a global termination state and all the allocated resources except for the cluster
partitions can be cleared.
|
Constructor and Description |
---|
JobShuffleContextImpl(JobID jobId,
JobMasterGateway jobMasterGateway) |
Modifier and Type | Method and Description |
---|---|
JobID |
ResourceRequirements.getJobId() |
Modifier and Type | Method and Description |
---|---|
static ResourceRequirements |
ResourceRequirements.create(JobID jobId,
String targetAddress,
Collection<ResourceRequirement> resourceRequirements) |
static ResourceRequirements |
ResourceRequirements.empty(JobID jobId,
String targetAddress) |
Modifier and Type | Field and Description |
---|---|
protected JobID |
TaskLocalStateStoreImpl.jobID
JobID from the owning subtask.
|
Modifier and Type | Method and Description |
---|---|
CheckpointStorageAccess |
CheckpointStorage.createCheckpointStorage(JobID jobId)
Creates a storage for checkpoints for the given job.
|
abstract <K> AbstractKeyedStateBackend<K> |
AbstractStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry) |
<K> CheckpointableKeyedStateBackend<K> |
StateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry)
Creates a new
CheckpointableKeyedStateBackend that is responsible for holding
keyed state and checkpointing it. |
abstract <K> AbstractKeyedStateBackend<K> |
AbstractManagedMemoryStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry,
double managedMemoryFraction) |
default <K> CheckpointableKeyedStateBackend<K> |
StateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry,
double managedMemoryFraction)
Creates a new
CheckpointableKeyedStateBackend with the given managed memory fraction. |
Optional<StateChangelogStorage<?>> |
TaskExecutorStateChangelogStoragesManager.getChangelogStoragesByJobId(JobID jobId) |
static Path |
ChangelogTaskLocalStateStore.getLocalTaskOwnedDirectory(LocalRecoveryDirectoryProvider provider,
JobID jobID) |
TaskLocalStateStore |
TaskExecutorLocalStateStoresManager.localStateStoreForSubtask(JobID jobId,
AllocationID allocationID,
JobVertexID jobVertexID,
int subtaskIndex,
Configuration clusterConfiguration,
Configuration jobConfiguration) |
void |
TaskExecutorStateChangelogStoragesManager.releaseResourcesForJob(JobID jobID) |
StateChangelogStorage<?> |
TaskExecutorStateChangelogStoragesManager.stateChangelogStorageForJob(JobID jobId,
Configuration configuration,
TaskManagerJobMetricGroup metricGroup,
LocalRecoveryConfig localRecoveryConfig) |
Constructor and Description |
---|
ChangelogTaskLocalStateStore(JobID jobID,
AllocationID allocationID,
JobVertexID jobVertexID,
int subtaskIndex,
LocalRecoveryConfig localRecoveryConfig,
Executor discardExecutor) |
LocalRecoveryDirectoryProviderImpl(File[] allocationBaseDirs,
JobID jobID,
JobVertexID jobVertexID,
int subtaskIndex) |
LocalRecoveryDirectoryProviderImpl(File allocationBaseDir,
JobID jobID,
JobVertexID jobVertexID,
int subtaskIndex) |
TaskLocalStateStoreImpl(JobID jobID,
AllocationID allocationID,
JobVertexID jobVertexID,
int subtaskIndex,
LocalRecoveryConfig localRecoveryConfig,
Executor discardExecutor) |
TaskStateManagerImpl(JobID jobId,
ExecutionAttemptID executionAttemptID,
TaskLocalStateStore localStateStore,
StateChangelogStorage<?> stateChangelogStorage,
TaskExecutorStateChangelogStoragesManager changelogStoragesManager,
JobManagerTaskRestore jobManagerTaskRestore,
CheckpointResponder checkpointResponder) |
TaskStateManagerImpl(JobID jobId,
ExecutionAttemptID executionAttemptID,
TaskLocalStateStore localStateStore,
StateChangelogStorage<?> stateChangelogStorage,
TaskExecutorStateChangelogStoragesManager changelogStoragesManager,
JobManagerTaskRestore jobManagerTaskRestore,
CheckpointResponder checkpointResponder,
SequentialChannelStateReaderImpl sequentialChannelStateReader) |
Modifier and Type | Method and Description |
---|---|
StateChangelogStorage<?> |
StateChangelogStorageFactory.createStorage(JobID jobID,
Configuration configuration,
TaskManagerJobMetricGroup metricGroup,
LocalRecoveryConfig localRecoveryConfig)
Create the storage based on a configuration.
|
static StateChangelogStorage<?> |
StateChangelogStorageLoader.load(JobID jobID,
Configuration configuration,
TaskManagerJobMetricGroup metricGroup,
LocalRecoveryConfig localRecoveryConfig) |
Modifier and Type | Method and Description |
---|---|
StateChangelogStorage<?> |
InMemoryStateChangelogStorageFactory.createStorage(JobID jobID,
Configuration configuration,
TaskManagerJobMetricGroup metricGroup,
LocalRecoveryConfig localRecoveryConfig) |
Modifier and Type | Method and Description |
---|---|
CheckpointStorageAccess |
FsStateBackend.createCheckpointStorage(JobID jobId)
Deprecated.
|
<K> AbstractKeyedStateBackend<K> |
FsStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry)
Deprecated.
|
protected static Path |
AbstractFsCheckpointStorageAccess.getCheckpointDirectoryForJob(Path baseCheckpointPath,
JobID jobId)
Builds directory into which a specific job checkpoints, meaning the directory inside which it
creates the checkpoint-specific subdirectories.
|
Constructor and Description |
---|
AbstractFsCheckpointStorageAccess(JobID jobId,
Path defaultSavepointDirectory)
Creates a new checkpoint storage.
|
FsCheckpointStorageAccess(FileSystem fs,
Path checkpointBaseDirectory,
Path defaultSavepointDirectory,
JobID jobId,
int fileSizeThreshold,
int writeBufferSize) |
FsCheckpointStorageAccess(Path checkpointBaseDirectory,
Path defaultSavepointDirectory,
JobID jobId,
int fileSizeThreshold,
int writeBufferSize) |
Modifier and Type | Method and Description |
---|---|
<K> AbstractKeyedStateBackend<K> |
HashMapStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry) |
Modifier and Type | Method and Description |
---|---|
CheckpointStorageAccess |
MemoryStateBackend.createCheckpointStorage(JobID jobId)
Deprecated.
|
<K> AbstractKeyedStateBackend<K> |
MemoryStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry)
Deprecated.
|
Constructor and Description |
---|
MemoryBackendCheckpointStorageAccess(JobID jobId,
Path checkpointsBaseDirectory,
Path defaultSavepointLocation,
int maxStateSize)
Creates a new MemoryBackendCheckpointStorage.
|
Modifier and Type | Method and Description |
---|---|
CheckpointStorageAccess |
FileSystemCheckpointStorage.createCheckpointStorage(JobID jobId) |
CheckpointStorageAccess |
JobManagerCheckpointStorage.createCheckpointStorage(JobID jobId) |
Modifier and Type | Method and Description |
---|---|
JobID |
JobTable.Job.getJobId()
Returns the
JobID which is associated with this job. |
JobID |
JobTable.Connection.getJobId() |
JobID |
SlotStatus.getJobID()
Get the job id of the slot allocated for.
|
Modifier and Type | Method and Description |
---|---|
void |
DefaultJobLeaderService.addJob(JobID jobId,
String defaultTargetAddress) |
void |
JobLeaderService.addJob(JobID jobId,
String defaultTargetAddress)
Add the given job to be monitored.
|
boolean |
DefaultJobLeaderService.containsJob(JobID jobId)
Check whether the service monitors the given job.
|
boolean |
JobLeaderService.containsJob(JobID jobId)
Check whether the service monitors the given job.
|
TaskKvStateRegistry |
KvStateService.createKvStateTaskRegistry(JobID jobId,
JobVertexID jobVertexId) |
void |
TaskExecutorGatewayDecoratorBase.disconnectJobManager(JobID jobId,
Exception cause) |
void |
TaskExecutor.disconnectJobManager(JobID jobId,
Exception cause) |
void |
TaskExecutorGateway.disconnectJobManager(JobID jobId,
Exception cause)
Disconnects the given JobManager from the TaskManager.
|
void |
TaskExecutorGatewayDecoratorBase.freeInactiveSlots(JobID jobId,
Time timeout) |
void |
TaskExecutor.freeInactiveSlots(JobID jobId,
Time timeout) |
void |
TaskExecutorGateway.freeInactiveSlots(JobID jobId,
Time timeout)
Frees all currently inactive slot allocated for the given job.
|
Optional<JobTable.Connection> |
DefaultJobTable.getConnection(JobID jobId) |
Optional<JobTable.Connection> |
JobTable.getConnection(JobID jobId)
Gets the connection registered under jobId.
|
Optional<JobTable.Job> |
DefaultJobTable.getJob(JobID jobId) |
Optional<JobTable.Job> |
JobTable.getJob(JobID jobId)
Gets the job registered under jobId.
|
<E extends Exception> |
DefaultJobTable.getOrCreateJob(JobID jobId,
SupplierWithException<? extends JobTable.JobServices,E> jobServicesSupplier) |
<E extends Exception> |
JobTable.getOrCreateJob(JobID jobId,
SupplierWithException<? extends JobTable.JobServices,E> jobServicesSupplier)
Gets a registered
JobTable.Job or creates one if not present. |
void |
JobLeaderListener.jobManagerGainedLeadership(JobID jobId,
JobMasterGateway jobManagerGateway,
JMTMRegistrationSuccess registrationMessage)
Callback if a job manager has gained leadership for the job identified by the job id and a
connection could be established to this job manager.
|
void |
JobLeaderListener.jobManagerLostLeadership(JobID jobId,
JobMasterId jobMasterId)
Callback if the job leader for the job with the given job id lost its leadership.
|
void |
JobLeaderListener.jobManagerRejectedRegistration(JobID jobId,
String targetAddress,
JMTMRegistrationRejection rejection)
Callback if a job manager rejected the connection attempts of a task manager.
|
CompletableFuture<Acknowledge> |
TaskExecutorGatewayDecoratorBase.promotePartitions(JobID jobId,
Set<ResultPartitionID> partitionIds) |
CompletableFuture<Acknowledge> |
TaskExecutor.promotePartitions(JobID jobId,
Set<ResultPartitionID> partitionIds) |
CompletableFuture<Acknowledge> |
TaskExecutorGateway.promotePartitions(JobID jobId,
Set<ResultPartitionID> partitionIds)
Batch promote intermediate result partitions.
|
void |
DefaultJobLeaderService.reconnect(JobID jobId) |
void |
JobLeaderService.reconnect(JobID jobId)
Triggers reconnection to the last known leader of the given job.
|
void |
TaskExecutorGatewayDecoratorBase.releasePartitions(JobID jobId,
Set<ResultPartitionID> partitionIds) |
void |
TaskExecutor.releasePartitions(JobID jobId,
Set<ResultPartitionID> partitionIds) |
void |
TaskExecutorGateway.releasePartitions(JobID jobId,
Set<ResultPartitionID> partitionIds)
Batch release intermediate result partitions.
|
void |
DefaultJobLeaderService.removeJob(JobID jobId) |
void |
JobLeaderService.removeJob(JobID jobId)
Remove the given job from being monitored by the job leader service.
|
CompletableFuture<ExecutionState> |
PartitionProducerStateChecker.requestPartitionProducerState(JobID jobId,
IntermediateDataSetID intermediateDataSetId,
ResultPartitionID resultPartitionId)
Requests the execution state of the execution producing a result partition.
|
CompletableFuture<Acknowledge> |
TaskExecutorGatewayDecoratorBase.requestSlot(SlotID slotId,
JobID jobId,
AllocationID allocationId,
ResourceProfile resourceProfile,
String targetAddress,
ResourceManagerId resourceManagerId,
Time timeout) |
CompletableFuture<Acknowledge> |
TaskExecutor.requestSlot(SlotID slotId,
JobID jobId,
AllocationID allocationId,
ResourceProfile resourceProfile,
String targetAddress,
ResourceManagerId resourceManagerId,
Time timeout) |
CompletableFuture<Acknowledge> |
TaskExecutorGateway.requestSlot(SlotID slotId,
JobID jobId,
AllocationID allocationId,
ResourceProfile resourceProfile,
String targetAddress,
ResourceManagerId resourceManagerId,
Time timeout)
Requests a slot from the TaskManager.
|
Constructor and Description |
---|
SlotStatus(SlotID slotID,
ResourceProfile resourceProfile,
JobID jobID,
AllocationID allocationID) |
Modifier and Type | Method and Description |
---|---|
JobID |
SlotOccupiedException.getJobId() |
Constructor and Description |
---|
SlotOccupiedException(String message,
AllocationID allocationId,
JobID jobId) |
Modifier and Type | Method and Description |
---|---|
void |
RpcCheckpointResponder.acknowledgeCheckpoint(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
CheckpointMetrics checkpointMetrics,
TaskStateSnapshot subtaskState) |
void |
RpcCheckpointResponder.declineCheckpoint(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
CheckpointException checkpointException) |
void |
RpcKvStateRegistryListener.notifyKvStateRegistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName,
KvStateID kvStateId) |
void |
RpcKvStateRegistryListener.notifyKvStateUnregistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName) |
void |
RpcCheckpointResponder.reportCheckpointMetrics(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
CheckpointMetrics checkpointMetrics) |
CompletableFuture<ExecutionState> |
RpcPartitionStateChecker.requestPartitionProducerState(JobID jobId,
IntermediateDataSetID resultId,
ResultPartitionID partitionId) |
Modifier and Type | Method and Description |
---|---|
JobID |
TaskSlot.getJobId() |
JobID |
SlotAllocationSnapshot.getJobId() |
JobID |
TaskSlotPayload.getJobID() |
JobID |
TaskSlotTable.getOwningJob(AllocationID allocationId)
Returns the owning job of the
TaskSlot identified by the given AllocationID . |
JobID |
TaskSlotTableImpl.getOwningJob(AllocationID allocationId) |
Modifier and Type | Method and Description |
---|---|
boolean |
TaskSlotTable.allocateSlot(int index,
JobID jobId,
AllocationID allocationId,
ResourceProfile resourceProfile,
Time slotTimeout)
Allocate the slot with the given index for the given job and allocation id.
|
boolean |
TaskSlotTableImpl.allocateSlot(int requestedIndex,
JobID jobId,
AllocationID allocationId,
ResourceProfile resourceProfile,
Time slotTimeout) |
boolean |
TaskSlotTable.allocateSlot(int index,
JobID jobId,
AllocationID allocationId,
Time slotTimeout)
Allocate the slot with the given index for the given job and allocation id.
|
boolean |
TaskSlotTableImpl.allocateSlot(int index,
JobID jobId,
AllocationID allocationId,
Time slotTimeout) |
Set<AllocationID> |
TaskSlotTable.getActiveTaskSlotAllocationIdsPerJob(JobID jobId)
|
Set<AllocationID> |
TaskSlotTableImpl.getActiveTaskSlotAllocationIdsPerJob(JobID jobId) |
Iterator<TaskSlot<T>> |
TaskSlotTable.getAllocatedSlots(JobID jobId)
Return an iterator of allocated slots for the given job id.
|
Iterator<TaskSlot<T>> |
TaskSlotTableImpl.getAllocatedSlots(JobID jobId) |
Set<AllocationID> |
TaskSlotTable.getAllocationIdsPerJob(JobID jobId)
Returns the all
AllocationID for the given job. |
Set<AllocationID> |
TaskSlotTableImpl.getAllocationIdsPerJob(JobID jobId) |
Iterator<T> |
TaskSlotTable.getTasks(JobID jobId)
Return an iterator over all tasks for a given job.
|
Iterator<T> |
TaskSlotTableImpl.getTasks(JobID jobId) |
boolean |
TaskSlotTable.hasAllocatedSlots(JobID jobId)
Check whether the job has allocated (not active) slots.
|
boolean |
TaskSlotTableImpl.hasAllocatedSlots(JobID jobId) |
boolean |
TaskSlot.isActive(JobID activeJobId,
AllocationID activeAllocationId) |
boolean |
TaskSlotTable.isAllocated(int index,
JobID jobId,
AllocationID allocationId)
Check whether the slot for the given index is allocated for the given job and allocation id.
|
boolean |
TaskSlotTableImpl.isAllocated(int index,
JobID jobId,
AllocationID allocationId) |
boolean |
TaskSlot.isAllocated(JobID jobIdToCheck,
AllocationID allocationIDToCheck) |
boolean |
TaskSlotTable.tryMarkSlotActive(JobID jobId,
AllocationID allocationId)
Try to mark the specified slot as active if it has been allocated by the given job.
|
boolean |
TaskSlotTableImpl.tryMarkSlotActive(JobID jobId,
AllocationID allocationId) |
Constructor and Description |
---|
SlotAllocationSnapshot(SlotID slotID,
JobID jobId,
String jobTargetAddress,
AllocationID allocationId,
ResourceProfile resourceProfile) |
SlotNotActiveException(JobID jobId,
AllocationID allocationId) |
TaskSlot(int index,
ResourceProfile resourceProfile,
int memoryPageSize,
JobID jobId,
AllocationID allocationId,
Executor asyncExecutor) |
Modifier and Type | Method and Description |
---|---|
JobID |
Task.getJobID() |
JobID |
RuntimeEnvironment.getJobID() |
Modifier and Type | Method and Description |
---|---|
void |
CheckpointResponder.acknowledgeCheckpoint(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
CheckpointMetrics checkpointMetrics,
TaskStateSnapshot subtaskState)
Acknowledges the given checkpoint.
|
void |
CheckpointResponder.declineCheckpoint(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
CheckpointException checkpointException)
Declines the given checkpoint.
|
void |
CheckpointResponder.reportCheckpointMetrics(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
CheckpointMetrics checkpointMetrics)
Report metrics for the given checkpoint.
|
Constructor and Description |
---|
RuntimeEnvironment(JobID jobId,
JobVertexID jobVertexId,
ExecutionAttemptID executionId,
ExecutionConfig executionConfig,
TaskInfo taskInfo,
Configuration jobConfiguration,
Configuration taskConfiguration,
UserCodeClassLoader userCodeClassLoader,
MemoryManager memManager,
IOManager ioManager,
BroadcastVariableManager bcVarManager,
TaskStateManager taskStateManager,
GlobalAggregateManager aggregateManager,
AccumulatorRegistry accumulatorRegistry,
TaskKvStateRegistry kvStateRegistry,
InputSplitProvider splitProvider,
Map<String,Future<Path>> distCacheEntries,
ResultPartitionWriter[] writers,
IndexedInputGate[] inputGates,
TaskEventDispatcher taskEventDispatcher,
CheckpointResponder checkpointResponder,
TaskOperatorEventGateway operatorEventGateway,
TaskManagerRuntimeInfo taskManagerInfo,
TaskMetricGroup metrics,
Task containingTask,
ExternalResourceInfoProvider externalResourceInfoProvider) |
Modifier and Type | Method and Description |
---|---|
static String |
ZooKeeperUtils.getLeaderPathForJob(JobID jobId) |
static String |
ZooKeeperUtils.getLeaderPathForJobManager(JobID jobId) |
static String |
ZooKeeperUtils.getPathForJob(JobID jobId)
Returns the JobID as a String (with leading slash).
|
static String |
ZooKeeperUtils.getSingleLeaderElectionPathForJobManager(JobID jobID) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
RestfulGateway.cancelJob(JobID jobId,
Time timeout)
Cancel the given job.
|
CompletableFuture<Acknowledge> |
NonLeaderRetrievalRestfulGateway.cancelJob(JobID jobId,
Time timeout) |
default CompletableFuture<CoordinationResponse> |
RestfulGateway.deliverCoordinationRequestToCoordinator(JobID jobId,
OperatorID operatorId,
SerializedValue<CoordinationRequest> serializedRequest,
Time timeout)
Deliver a coordination request to a specified coordinator and return the response.
|
CompletableFuture<ExecutionGraphInfo> |
RestfulGateway.requestExecutionGraphInfo(JobID jobId,
Time timeout)
Requests the
ExecutionGraphInfo containing additional information besides the ArchivedExecutionGraph . |
CompletableFuture<ExecutionGraphInfo> |
NonLeaderRetrievalRestfulGateway.requestExecutionGraphInfo(JobID jobId,
Time timeout) |
default CompletableFuture<ArchivedExecutionGraph> |
RestfulGateway.requestJob(JobID jobId,
Time timeout)
Requests the
ArchivedExecutionGraph for the given jobId. |
CompletableFuture<JobResult> |
RestfulGateway.requestJobResult(JobID jobId,
Time timeout)
Requests the
JobResult of a job specified by the given jobId. |
CompletableFuture<JobResult> |
NonLeaderRetrievalRestfulGateway.requestJobResult(JobID jobId,
Time timeout) |
default CompletableFuture<JobStatus> |
RestfulGateway.requestJobStatus(JobID jobId,
Time timeout)
Request the
JobStatus of the given job. |
Modifier and Type | Method and Description |
---|---|
JobID |
JarRunResponseBody.getJobId() |
JobID |
JarRequestBody.getJobId() |
Constructor and Description |
---|
JarRunRequestBody(String entryClassName,
String programArguments,
List<String> programArgumentsList,
Integer parallelism,
JobID jobId,
Boolean allowNonRestoredState,
String savepointPath,
RestoreMode restoreMode) |
JarRunResponseBody(JobID jobId) |
Modifier and Type | Method and Description |
---|---|
Optional<T> |
JobVertexStatsTracker.getVertexStats(JobID jobId,
AccessExecutionJobVertex vertex)
Returns statistics for a job vertex.
|
Modifier and Type | Method and Description |
---|---|
Optional<T> |
JobVertexThreadInfoTracker.getVertexStats(JobID jobId,
AccessExecutionJobVertex vertex) |
Modifier and Type | Method and Description |
---|---|
JobID |
SavepointRuntimeContext.getJobId() |
JobID |
SavepointEnvironment.getJobID() |
Modifier and Type | Method and Description |
---|---|
<K> CheckpointableKeyedStateBackend<K> |
AbstractChangelogStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry) |
<K> CheckpointableKeyedStateBackend<K> |
AbstractChangelogStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry,
double managedMemoryFraction) |
Modifier and Type | Method and Description |
---|---|
static JobGraph |
StreamingJobGraphGenerator.createJobGraph(ClassLoader userClassLoader,
StreamGraph streamGraph,
JobID jobID) |
JobGraph |
StreamGraph.getJobGraph(ClassLoader userClassLoader,
JobID jobID)
|
Modifier and Type | Method and Description |
---|---|
JobID |
StreamingRuntimeContext.getJobId() |
Modifier and Type | Method and Description |
---|---|
CheckpointStorageAccess |
BatchExecutionCheckpointStorage.createCheckpointStorage(JobID jobId) |
<K> CheckpointableKeyedStateBackend<K> |
BatchExecutionStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry) |
Modifier and Type | Method and Description |
---|---|
static String |
StreamIterationHead.createBrokerIdString(JobID jid,
String iterationID,
int subtaskIndex)
Creates the identification string with which head and tail task find the shared blocking
queue for the back channel.
|
Modifier and Type | Method and Description |
---|---|
static void |
TestUtils.waitUntilJobCanceled(JobID jobId,
ClusterClient<?> client) |
Modifier and Type | Method and Description |
---|---|
JobID |
FlinkDistribution.submitJob(JobSubmission jobSubmission,
java.time.Duration timeout) |
Copyright © 2014–2022 The Apache Software Foundation. All rights reserved.