Uses of Class
org.apache.flink.runtime.executiongraph.JobInformation
-
Packages that use JobInformation Package Description org.apache.flink.runtime.deployment org.apache.flink.runtime.executiongraph org.apache.flink.runtime.taskexecutor org.apache.flink.runtime.taskmanager -
-
Uses of JobInformation in org.apache.flink.runtime.deployment
Methods in org.apache.flink.runtime.deployment that return JobInformation Modifier and Type Method Description JobInformation
TaskDeploymentDescriptor. getJobInformation()
Return the sub task's job information.Methods in org.apache.flink.runtime.deployment that return types with arguments of type JobInformation Modifier and Type Method Description TaskDeploymentDescriptor.MaybeOffloaded<JobInformation>
TaskDeploymentDescriptorFactory. getSerializedJobInformation()
Method parameters in org.apache.flink.runtime.deployment with type arguments of type JobInformation Modifier and Type Method Description void
TaskDeploymentDescriptor. loadBigData(PermanentBlobService blobService, GroupCache<org.apache.flink.api.common.JobID,PermanentBlobKey,JobInformation> jobInformationCache, GroupCache<org.apache.flink.api.common.JobID,PermanentBlobKey,TaskInformation> taskInformationCache, GroupCache<org.apache.flink.api.common.JobID,PermanentBlobKey,TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup> shuffleDescriptorsCache)
Loads externalized data from the BLOB store back to the object.Constructor parameters in org.apache.flink.runtime.deployment with type arguments of type JobInformation Constructor Description TaskDeploymentDescriptor(org.apache.flink.api.common.JobID jobId, TaskDeploymentDescriptor.MaybeOffloaded<JobInformation> serializedJobInformation, TaskDeploymentDescriptor.MaybeOffloaded<TaskInformation> serializedTaskInformation, ExecutionAttemptID executionAttemptId, AllocationID allocationId, JobManagerTaskRestore taskRestore, List<ResultPartitionDeploymentDescriptor> resultPartitionDeploymentDescriptors, List<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors)
TaskDeploymentDescriptorFactory(org.apache.flink.types.Either<org.apache.flink.util.SerializedValue<JobInformation>,PermanentBlobKey> jobInformationOrBlobKey, org.apache.flink.api.common.JobID jobID, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionDeploymentConstraint, BlobWriter blobWriter, boolean nonFinishedHybridPartitionShouldBeUnknown, int offloadShuffleDescriptorsThreshold)
-
Uses of JobInformation in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return JobInformation Modifier and Type Method Description JobInformation
JobInformation. deepCopy()
Constructors in org.apache.flink.runtime.executiongraph with parameters of type JobInformation Constructor Description DefaultExecutionGraph(JobInformation jobInformation, ScheduledExecutorService futureExecutor, Executor ioExecutor, Duration rpcTimeout, int executionHistorySizeLimit, ClassLoader userClassLoader, BlobWriter blobWriter, PartitionGroupReleaseStrategy.Factory partitionGroupReleaseStrategyFactory, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentListener executionDeploymentListener, ExecutionStateUpdateListener executionStateUpdateListener, long initializationTimestamp, VertexAttemptNumberStore initialAttemptCounts, VertexParallelismStore vertexParallelismStore, boolean isDynamic, ExecutionJobVertex.Factory executionJobVertexFactory, List<org.apache.flink.core.execution.JobStatusHook> jobStatusHooks, MarkPartitionFinishedStrategy markPartitionFinishedStrategy, TaskDeploymentDescriptorFactory taskDeploymentDescriptorFactory, List<org.apache.flink.core.execution.JobStatusChangedListener> jobStatusChangedListeners, ExecutionPlanSchedulingContext executionPlanSchedulingContext)
-
Uses of JobInformation in org.apache.flink.runtime.taskexecutor
Methods in org.apache.flink.runtime.taskexecutor that return types with arguments of type JobInformation Modifier and Type Method Description GroupCache<org.apache.flink.api.common.JobID,PermanentBlobKey,JobInformation>
TaskManagerServices. getJobInformationCache()
-
Uses of JobInformation in org.apache.flink.runtime.taskmanager
Constructors in org.apache.flink.runtime.taskmanager with parameters of type JobInformation Constructor Description Task(JobInformation jobInformation, TaskInformation taskInformation, ExecutionAttemptID executionAttemptID, AllocationID slotAllocationId, List<ResultPartitionDeploymentDescriptor> resultPartitionDeploymentDescriptors, List<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors, MemoryManager memManager, SharedResources sharedResources, IOManager ioManager, ShuffleEnvironment<?,?> shuffleEnvironment, KvStateService kvStateService, BroadcastVariableManager bcVarManager, TaskEventDispatcher taskEventDispatcher, ExternalResourceInfoProvider externalResourceInfoProvider, TaskStateManager taskStateManager, TaskManagerActions taskManagerActions, InputSplitProvider inputSplitProvider, CheckpointResponder checkpointResponder, TaskOperatorEventGateway operatorCoordinatorEventGateway, GlobalAggregateManager aggregateManager, LibraryCacheManager.ClassLoaderHandle classLoaderHandle, FileCache fileCache, TaskManagerRuntimeInfo taskManagerConfig, TaskMetricGroup metricGroup, PartitionProducerStateChecker partitionProducerStateChecker, Executor executor, ChannelStateWriteRequestExecutorFactory channelStateExecutorFactory)
IMPORTANT: This constructor may not start any work that would need to be undone in the case of a failing task deployment.
-