Package | Description |
---|---|
org.apache.flink.runtime.dispatcher | |
org.apache.flink.runtime.jobmaster | |
org.apache.flink.runtime.jobmaster.factories |
Modifier and Type | Method and Description |
---|---|
JobManagerRunner |
DefaultJobManagerRunnerFactory.createJobManagerRunner(JobGraph jobGraph,
Configuration configuration,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
JobManagerSharedServices jobManagerServices,
JobManagerJobMetricGroupFactory jobManagerJobMetricGroupFactory,
FatalErrorHandler fatalErrorHandler) |
JobManagerRunner |
JobManagerRunnerFactory.createJobManagerRunner(JobGraph jobGraph,
Configuration configuration,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
JobManagerSharedServices jobManagerServices,
JobManagerJobMetricGroupFactory jobManagerJobMetricGroupFactory,
FatalErrorHandler fatalErrorHandler) |
Modifier and Type | Method and Description |
---|---|
static JobManagerSharedServices |
JobManagerSharedServices.fromConfiguration(Configuration config,
BlobServer blobServer,
FatalErrorHandler fatalErrorHandler) |
Constructor and Description |
---|
JobMaster(RpcService rpcService,
JobMasterConfiguration jobMasterConfiguration,
ResourceID resourceId,
JobGraph jobGraph,
HighAvailabilityServices highAvailabilityService,
SlotPoolFactory slotPoolFactory,
SchedulerFactory schedulerFactory,
JobManagerSharedServices jobManagerSharedServices,
HeartbeatServices heartbeatServices,
JobManagerJobMetricGroupFactory jobMetricGroupFactory,
OnCompletionActions jobCompletionActions,
FatalErrorHandler fatalErrorHandler,
ClassLoader userCodeLoader,
SchedulerNGFactory schedulerNGFactory,
ShuffleMaster<?> shuffleMaster,
PartitionTrackerFactory partitionTrackerFactory) |
Constructor and Description |
---|
DefaultJobMasterServiceFactory(JobMasterConfiguration jobMasterConfiguration,
SlotPoolFactory slotPoolFactory,
SchedulerFactory schedulerFactory,
RpcService rpcService,
HighAvailabilityServices haServices,
JobManagerSharedServices jobManagerSharedServices,
HeartbeatServices heartbeatServices,
JobManagerJobMetricGroupFactory jobManagerJobMetricGroupFactory,
FatalErrorHandler fatalErrorHandler,
SchedulerNGFactory schedulerNGFactory,
ShuffleMaster<?> shuffleMaster) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.