Package org.apache.flink.runtime.jobmaster
-
Interface Summary Interface Description ExecutionDeploymentReconciler Component for reconciling the deployment state of executions.ExecutionDeploymentReconciler.Factory Factory forExecutionDeploymentReconciler
.ExecutionDeploymentReconciliationHandler Interface for triggering actions in case of state mismatches.ExecutionDeploymentTracker A tracker for deployed executions.JobManagerRunner Interface for a runner which executes aJobMaster
.JobMasterGateway JobMaster
rpc gateway interface.JobMasterOperatorEventGateway Gateway to send anOperatorEvent
orCoordinationRequest
from the Task Manager to to theOperatorCoordinator
on the JobManager side.JobMasterService Interface which specifies the JobMaster service.JobMasterServiceProcess JobMasterServiceProcess is responsible for running aJobMasterService
.KvStateLocationOracle Oracle forKvStateLocation
in the cluster.KvStateRegistryGateway Gateway to report key-value state registration and deregistrations.LogicalSlot A logical slot represents a resource on a TaskManager into which a single task can be deployed.LogicalSlot.Payload Payload for a logical slot.ServiceConnectionManager<S> Base interface for managers of services that are explicitly connected to / disconnected from.SlotContext Interface for the context of aLogicalSlot
.SlotInfo Interface that provides basic information in the context of a slot.SlotOwner Interface for components that hold slots and to which slots get released / recycled.SlotPoolServiceSchedulerFactory Factory forSlotPoolService
andSchedulerNG
. -
Class Summary Class Description AllocatedSlotInfo Information about an allocated slot which is owned by a JobMaster.AllocatedSlotReport The report of currently allocated slots from a given TaskExecutor by a JobMaster.DefaultExecutionDeploymentReconciler DefaultExecutionDeploymentReconciler
implementation.DefaultExecutionDeploymentTracker DefaultExecutionDeploymentTracker
implementation.DefaultJobMasterServiceProcess DefaultJobMasterServiceProcess
which is responsible for creating and running aJobMasterService
.DefaultSlotPoolServiceSchedulerFactory DefaultSlotPoolServiceSchedulerFactory
implementation.ExecutionDeploymentTrackerDeploymentListenerAdapter An adapter for using anExecutionDeploymentTracker
as anExecutionDeploymentListener
.JMTMRegistrationRejection Message indicating a registration rejection from theJobMaster
for theTaskExecutor
.JMTMRegistrationSuccess Message indicating a successfulJobMaster
andTaskExecutor
registration.JobManagerRunnerResult The result of theJobManagerRunner
.JobManagerSharedServices Utility class which holds all auxiliary shared services used by theJobMaster
.JobMaster JobMaster implementation.JobMasterConfiguration Configuration for theJobMaster
.JobMasterId TheJobMaster
fencing token.JobMasterRegistrationSuccess Base class for responses from the ResourceManager to a registration attempt by a JobMaster.JobMasterServiceLeadershipRunner Leadership runner for theJobMasterServiceProcess
.JobResult Similar toJobExecutionResult
but with an optionalSerializedThrowable
when the job failed.JobResult.Builder Builder forJobResult
.MiniDispatcherRestEndpoint REST endpoint for the ApplicationClusterEntryPoint.ResourceManagerAddress Current address and fencing token of the leading ResourceManager.RpcTaskManagerGateway Implementation of theTaskManagerGateway
for Flink's RPC system.SerializedInputSplit SlotRequestId This ID identifies the request for a slot from the Execution to theSlotPool
orPhysicalSlotProvider
.TaskManagerRegistrationInformation DTO for TaskManager registration information. -
Enum Summary Enum Description ExecutionDeploymentState Possible states for the deployment of an execution.JobMasterServiceProcess.WaitingForLeadership -
Exception Summary Exception Description ExecutionGraphException Exceptions thrown by operations on theExecutionGraph
by theJobMaster
.JobManagerException Base exception thrown by theJobMaster
.JobMasterException Base class forJobMaster
related exceptions.JobNotFinishedException Exception indicating that a Flink job has not been finished.