Modifier and Type | Field and Description |
---|---|
protected HighAvailabilityServices |
ClusterClient.highAvailabilityServices
Service factory for high available.
|
Constructor and Description |
---|
ClusterClient(Configuration flinkConfig,
HighAvailabilityServices highAvailabilityServices,
boolean sharedHaServices)
Creates a instance that submits the programs to the JobManager defined in the
configuration.
|
ClusterClient(Configuration flinkConfig,
HighAvailabilityServices highAvailabilityServices,
boolean sharedHaServices,
ActorSystemLoader actorSystemLoader) |
Modifier and Type | Method and Description |
---|---|
ResourceManager<RegisteredMesosWorkerNode> |
MesosResourceManagerFactory.createResourceManager(Configuration configuration,
ResourceID resourceId,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
MetricRegistry metricRegistry,
FatalErrorHandler fatalErrorHandler,
ClusterInformation clusterInformation,
String webInterfaceUrl,
JobManagerMetricGroup jobManagerMetricGroup) |
Constructor and Description |
---|
MesosResourceManager(RpcService rpcService,
String resourceManagerEndpointId,
ResourceID resourceId,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
SlotManager slotManager,
MetricRegistry metricRegistry,
JobLeaderIdService jobLeaderIdService,
ClusterInformation clusterInformation,
FatalErrorHandler fatalErrorHandler,
Configuration flinkConfig,
MesosServices mesosServices,
MesosConfiguration mesosConfig,
MesosTaskManagerParameters taskManagerParameters,
ContainerSpecification taskManagerContainerSpec,
String webUiUrl,
JobManagerMetricGroup jobManagerMetricGroup) |
Modifier and Type | Method and Description |
---|---|
Dispatcher |
SessionDispatcherFactory.createDispatcher(Configuration configuration,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
GatewayRetriever<ResourceManagerGateway> resourceManagerGatewayRetriever,
BlobServer blobServer,
HeartbeatServices heartbeatServices,
JobManagerMetricGroup jobManagerMetricGroup,
String metricQueryServicePath,
ArchivedExecutionGraphStore archivedExecutionGraphStore,
FatalErrorHandler fatalErrorHandler,
HistoryServerArchivist historyServerArchivist) |
T |
DispatcherFactory.createDispatcher(Configuration configuration,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
GatewayRetriever<ResourceManagerGateway> resourceManagerGatewayRetriever,
BlobServer blobServer,
HeartbeatServices heartbeatServices,
JobManagerMetricGroup jobManagerMetricGroup,
String metricQueryServicePath,
ArchivedExecutionGraphStore archivedExecutionGraphStore,
FatalErrorHandler fatalErrorHandler,
HistoryServerArchivist historyServerArchivist)
Create a
Dispatcher of the given type T . |
MiniDispatcher |
JobDispatcherFactory.createDispatcher(Configuration configuration,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
GatewayRetriever<ResourceManagerGateway> resourceManagerGatewayRetriever,
BlobServer blobServer,
HeartbeatServices heartbeatServices,
JobManagerMetricGroup jobManagerMetricGroup,
String metricQueryServicePath,
ArchivedExecutionGraphStore archivedExecutionGraphStore,
FatalErrorHandler fatalErrorHandler,
HistoryServerArchivist historyServerArchivist) |
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) |
Constructor and Description |
---|
Dispatcher(RpcService rpcService,
String endpointId,
Configuration configuration,
HighAvailabilityServices highAvailabilityServices,
SubmittedJobGraphStore submittedJobGraphStore,
GatewayRetriever<ResourceManagerGateway> resourceManagerGatewayRetriever,
BlobServer blobServer,
HeartbeatServices heartbeatServices,
JobManagerMetricGroup jobManagerMetricGroup,
String metricServiceQueryPath,
ArchivedExecutionGraphStore archivedExecutionGraphStore,
JobManagerRunnerFactory jobManagerRunnerFactory,
FatalErrorHandler fatalErrorHandler,
HistoryServerArchivist historyServerArchivist) |
MiniDispatcher(RpcService rpcService,
String endpointId,
Configuration configuration,
HighAvailabilityServices highAvailabilityServices,
GatewayRetriever<ResourceManagerGateway> resourceManagerGatewayRetriever,
BlobServer blobServer,
HeartbeatServices heartbeatServices,
JobManagerMetricGroup jobManagerMetricGroup,
String metricQueryServicePath,
ArchivedExecutionGraphStore archivedExecutionGraphStore,
JobManagerRunnerFactory jobManagerRunnerFactory,
FatalErrorHandler fatalErrorHandler,
HistoryServerArchivist historyServerArchivist,
JobGraph jobGraph,
ClusterEntrypoint.ExecutionMode executionMode) |
StandaloneDispatcher(RpcService rpcService,
String endpointId,
Configuration configuration,
HighAvailabilityServices highAvailabilityServices,
GatewayRetriever<ResourceManagerGateway> resourceManagerGatewayRetriever,
BlobServer blobServer,
HeartbeatServices heartbeatServices,
JobManagerMetricGroup jobManagerMetricGroup,
String metricQueryServicePath,
ArchivedExecutionGraphStore archivedExecutionGraphStore,
JobManagerRunnerFactory jobManagerRunnerFactory,
FatalErrorHandler fatalErrorHandler,
HistoryServerArchivist historyServerArchivist) |
Modifier and Type | Method and Description |
---|---|
protected HighAvailabilityServices |
ClusterEntrypoint.createHaServices(Configuration configuration,
Executor executor) |
Modifier and Type | Method and Description |
---|---|
DispatcherResourceManagerComponent<T> |
DispatcherResourceManagerComponentFactory.create(Configuration configuration,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
BlobServer blobServer,
HeartbeatServices heartbeatServices,
MetricRegistry metricRegistry,
ArchivedExecutionGraphStore archivedExecutionGraphStore,
MetricQueryServiceRetriever metricQueryServiceRetriever,
FatalErrorHandler fatalErrorHandler) |
DispatcherResourceManagerComponent<T> |
AbstractDispatcherResourceManagerComponentFactory.create(Configuration configuration,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
BlobServer blobServer,
HeartbeatServices heartbeatServices,
MetricRegistry metricRegistry,
ArchivedExecutionGraphStore archivedExecutionGraphStore,
MetricQueryServiceRetriever metricQueryServiceRetriever,
FatalErrorHandler fatalErrorHandler) |
Modifier and Type | Method and Description |
---|---|
static HighAvailabilityServices |
HighAvailabilityServicesUtils.createAvailableOrEmbeddedServices(Configuration config,
Executor executor) |
HighAvailabilityServices |
HighAvailabilityServicesFactory.createHAServices(Configuration configuration,
Executor executor)
Creates an
HighAvailabilityServices instance. |
static HighAvailabilityServices |
HighAvailabilityServicesUtils.createHighAvailabilityServices(Configuration configuration,
Executor executor,
HighAvailabilityServicesUtils.AddressResolution addressResolution) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractNonHaServices
Abstract base class for non high-availability services.
|
Modifier and Type | Class and Description |
---|---|
class |
EmbeddedHaServices
An implementation of the
HighAvailabilityServices for the non-high-availability case
where all participants (ResourceManager, JobManagers, TaskManagers) run in the same process. |
Modifier and Type | Class and Description |
---|---|
class |
StandaloneHaServices
An implementation of the
HighAvailabilityServices for the non-high-availability case. |
Modifier and Type | Class and Description |
---|---|
class |
ZooKeeperHaServices
An implementation of the
HighAvailabilityServices using Apache ZooKeeper. |
Constructor and Description |
---|
JobManagerRunner(JobGraph jobGraph,
JobMasterServiceFactory jobMasterFactory,
HighAvailabilityServices haServices,
LibraryCacheManager libraryCacheManager,
Executor executor,
FatalErrorHandler fatalErrorHandler)
Exceptions that occur while creating the JobManager or JobManagerRunner are directly
thrown and not reported to the given
FatalErrorHandler . |
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) |
Constructor and Description |
---|
DefaultJobMasterServiceFactory(JobMasterConfiguration jobMasterConfiguration,
SlotPoolFactory slotPoolFactory,
SchedulerFactory schedulerFactory,
RpcService rpcService,
HighAvailabilityServices haServices,
JobManagerSharedServices jobManagerSharedServices,
HeartbeatServices heartbeatServices,
JobManagerJobMetricGroupFactory jobManagerJobMetricGroupFactory,
FatalErrorHandler fatalErrorHandler) |
Modifier and Type | Method and Description |
---|---|
protected HighAvailabilityServices |
MiniCluster.createHighAvailabilityServices(Configuration configuration,
Executor executor) |
HighAvailabilityServices |
MiniCluster.getHighAvailabilityServices() |
Modifier and Type | Method and Description |
---|---|
protected Collection<? extends DispatcherResourceManagerComponent<?>> |
MiniCluster.createDispatcherResourceManagerComponents(Configuration configuration,
MiniCluster.RpcServiceFactory rpcServiceFactory,
HighAvailabilityServices haServices,
BlobServer blobServer,
HeartbeatServices heartbeatServices,
MetricRegistry metricRegistry,
MetricQueryServiceRetriever metricQueryServiceRetriever,
FatalErrorHandler fatalErrorHandler) |
Modifier and Type | Method and Description |
---|---|
ResourceManager<ResourceID> |
StandaloneResourceManagerFactory.createResourceManager(Configuration configuration,
ResourceID resourceId,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
MetricRegistry metricRegistry,
FatalErrorHandler fatalErrorHandler,
ClusterInformation clusterInformation,
String webInterfaceUrl,
JobManagerMetricGroup jobManagerMetricGroup) |
ResourceManager<T> |
ResourceManagerFactory.createResourceManager(Configuration configuration,
ResourceID resourceId,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
MetricRegistry metricRegistry,
FatalErrorHandler fatalErrorHandler,
ClusterInformation clusterInformation,
String webInterfaceUrl,
JobManagerMetricGroup jobManagerMetricGroup) |
static ResourceManagerRuntimeServices |
ResourceManagerRuntimeServices.fromConfiguration(ResourceManagerRuntimeServicesConfiguration configuration,
HighAvailabilityServices highAvailabilityServices,
ScheduledExecutor scheduledExecutor) |
Constructor and Description |
---|
JobLeaderIdService(HighAvailabilityServices highAvailabilityServices,
ScheduledExecutor scheduledExecutor,
Time jobTimeout) |
ResourceManager(RpcService rpcService,
String resourceManagerEndpointId,
ResourceID resourceId,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
SlotManager slotManager,
MetricRegistry metricRegistry,
JobLeaderIdService jobLeaderIdService,
ClusterInformation clusterInformation,
FatalErrorHandler fatalErrorHandler,
JobManagerMetricGroup jobManagerMetricGroup) |
StandaloneResourceManager(RpcService rpcService,
String resourceManagerEndpointId,
ResourceID resourceId,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
SlotManager slotManager,
MetricRegistry metricRegistry,
JobLeaderIdService jobLeaderIdService,
ClusterInformation clusterInformation,
FatalErrorHandler fatalErrorHandler,
JobManagerMetricGroup jobManagerMetricGroup) |
Modifier and Type | Method and Description |
---|---|
static RpcService |
TaskManagerRunner.createRpcService(Configuration configuration,
HighAvailabilityServices haServices)
Create a RPC service for the task manager.
|
void |
JobLeaderService.start(String initialOwnerAddress,
RpcService initialRpcService,
HighAvailabilityServices initialHighAvailabilityServices,
JobLeaderListener initialJobLeaderListener)
Start the job leader service with the given services.
|
static TaskExecutor |
TaskManagerRunner.startTaskManager(Configuration configuration,
ResourceID resourceID,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
MetricRegistry metricRegistry,
BlobCacheService blobCacheService,
boolean localCommunicationOnly,
FatalErrorHandler fatalErrorHandler) |
Constructor and Description |
---|
TaskExecutor(RpcService rpcService,
TaskManagerConfiguration taskManagerConfiguration,
HighAvailabilityServices haServices,
TaskManagerServices taskExecutorServices,
HeartbeatServices heartbeatServices,
TaskManagerMetricGroup taskManagerMetricGroup,
String metricQueryServicePath,
BlobCacheService blobCacheService,
FatalErrorHandler fatalErrorHandler) |
Constructor and Description |
---|
YarnResourceManager(RpcService rpcService,
String resourceManagerEndpointId,
ResourceID resourceId,
Configuration flinkConfig,
Map<String,String> env,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
SlotManager slotManager,
MetricRegistry metricRegistry,
JobLeaderIdService jobLeaderIdService,
ClusterInformation clusterInformation,
FatalErrorHandler fatalErrorHandler,
String webInterfaceUrl,
JobManagerMetricGroup jobManagerMetricGroup) |
Modifier and Type | Method and Description |
---|---|
ResourceManager<YarnWorkerNode> |
YarnResourceManagerFactory.createResourceManager(Configuration configuration,
ResourceID resourceId,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
MetricRegistry metricRegistry,
FatalErrorHandler fatalErrorHandler,
ClusterInformation clusterInformation,
String webInterfaceUrl,
JobManagerMetricGroup jobManagerMetricGroup) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractYarnNonHaServices
Abstract base class for the high availability services for Flink YARN applications that support
no master fail over.
|
class |
YarnHighAvailabilityServices
The basis of
HighAvailabilityServices for YARN setups. |
class |
YarnIntraNonHaMasterServices
These YarnHighAvailabilityServices are for the Application Master in setups where there is one
ResourceManager that is statically configured in the Flink configuration.
|
class |
YarnPreConfiguredMasterNonHaServices
These YarnHighAvailabilityServices are for use by the TaskManager in setups,
where there is one ResourceManager that is statically configured in the Flink configuration.
|
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.