Modifier and Type | Method and Description |
---|---|
DispatcherLeaderProcessFactory |
ApplicationDispatcherLeaderProcessFactoryFactory.createFactory(JobPersistenceComponentFactory jobPersistenceComponentFactory,
Executor ioExecutor,
RpcService rpcService,
PartialDispatcherServices partialDispatcherServices,
FatalErrorHandler fatalErrorHandler) |
Constructor and Description |
---|
ApplicationDispatcherGatewayServiceFactory(Configuration configuration,
DispatcherFactory dispatcherFactory,
PackagedProgram application,
RpcService rpcService,
PartialDispatcherServices partialDispatcherServices) |
Modifier and Type | Method and Description |
---|---|
StandaloneDispatcher |
SessionDispatcherFactory.createDispatcher(RpcService rpcService,
DispatcherId fencingToken,
Collection<JobGraph> recoveredJobs,
Collection<JobResult> recoveredDirtyJobResults,
DispatcherBootstrapFactory dispatcherBootstrapFactory,
PartialDispatcherServicesWithJobPersistenceComponents partialDispatcherServicesWithJobPersistenceComponents) |
Dispatcher |
DispatcherFactory.createDispatcher(RpcService rpcService,
DispatcherId fencingToken,
Collection<JobGraph> recoveredJobs,
Collection<JobResult> recoveredDirtyJobResults,
DispatcherBootstrapFactory dispatcherBootstrapFactory,
PartialDispatcherServicesWithJobPersistenceComponents partialDispatcherServicesWithJobPersistenceComponents)
Create a
Dispatcher . |
MiniDispatcher |
JobDispatcherFactory.createDispatcher(RpcService rpcService,
DispatcherId fencingToken,
Collection<JobGraph> recoveredJobs,
Collection<JobResult> recoveredDirtyJobResults,
DispatcherBootstrapFactory dispatcherBootstrapFactory,
PartialDispatcherServicesWithJobPersistenceComponents partialDispatcherServicesWithJobPersistenceComponents) |
JobManagerRunner |
JobManagerRunnerFactory.createJobManagerRunner(JobGraph jobGraph,
Configuration configuration,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
JobManagerSharedServices jobManagerServices,
JobManagerJobMetricGroupFactory jobManagerJobMetricGroupFactory,
FatalErrorHandler fatalErrorHandler,
long initializationTimestamp) |
JobManagerRunner |
JobMasterServiceLeadershipRunnerFactory.createJobManagerRunner(JobGraph jobGraph,
Configuration configuration,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
JobManagerSharedServices jobManagerServices,
JobManagerJobMetricGroupFactory jobManagerJobMetricGroupFactory,
FatalErrorHandler fatalErrorHandler,
long initializationTimestamp) |
Constructor and Description |
---|
Dispatcher(RpcService rpcService,
DispatcherId fencingToken,
Collection<JobGraph> recoveredJobs,
Collection<JobResult> recoveredDirtyJobs,
DispatcherBootstrapFactory dispatcherBootstrapFactory,
DispatcherServices dispatcherServices) |
Dispatcher(RpcService rpcService,
DispatcherId fencingToken,
Collection<JobGraph> recoveredJobs,
Collection<JobResult> recoveredDirtyJobs,
DispatcherBootstrapFactory dispatcherBootstrapFactory,
DispatcherServices dispatcherServices,
JobManagerRunnerRegistry jobManagerRunnerRegistry,
ResourceCleanerFactory resourceCleanerFactory) |
MiniDispatcher(RpcService rpcService,
DispatcherId fencingToken,
DispatcherServices dispatcherServices,
JobGraph jobGraph,
JobResult recoveredDirtyJob,
DispatcherBootstrapFactory dispatcherBootstrapFactory,
ClusterEntrypoint.ExecutionMode executionMode) |
MiniDispatcher(RpcService rpcService,
DispatcherId fencingToken,
DispatcherServices dispatcherServices,
JobGraph jobGraph,
JobResult recoveredDirtyJob,
DispatcherBootstrapFactory dispatcherBootstrapFactory,
JobManagerRunnerRegistry jobManagerRunnerRegistry,
ResourceCleanerFactory resourceCleanerFactory,
ClusterEntrypoint.ExecutionMode executionMode) |
StandaloneDispatcher(RpcService rpcService,
DispatcherId fencingToken,
Collection<JobGraph> recoveredJobs,
Collection<JobResult> recoveredDirtyJobResults,
DispatcherBootstrapFactory dispatcherBootstrapFactory,
DispatcherServices dispatcherServices) |
Modifier and Type | Method and Description |
---|---|
DispatcherRunner |
DefaultDispatcherRunnerFactory.createDispatcherRunner(LeaderElectionService leaderElectionService,
FatalErrorHandler fatalErrorHandler,
JobPersistenceComponentFactory jobPersistenceComponentFactory,
Executor ioExecutor,
RpcService rpcService,
PartialDispatcherServices partialDispatcherServices) |
DispatcherRunner |
DispatcherRunnerFactory.createDispatcherRunner(LeaderElectionService leaderElectionService,
FatalErrorHandler fatalErrorHandler,
JobPersistenceComponentFactory jobPersistenceComponentFactory,
Executor ioExecutor,
RpcService rpcService,
PartialDispatcherServices partialDispatcherServices) |
DispatcherLeaderProcessFactory |
DispatcherLeaderProcessFactoryFactory.createFactory(JobPersistenceComponentFactory jobPersistenceComponentFactory,
Executor ioExecutor,
RpcService rpcService,
PartialDispatcherServices partialDispatcherServices,
FatalErrorHandler fatalErrorHandler) |
JobDispatcherLeaderProcessFactory |
JobDispatcherLeaderProcessFactoryFactory.createFactory(JobPersistenceComponentFactory jobPersistenceComponentFactory,
Executor ioExecutor,
RpcService rpcService,
PartialDispatcherServices partialDispatcherServices,
FatalErrorHandler fatalErrorHandler) |
DispatcherLeaderProcessFactory |
SessionDispatcherLeaderProcessFactoryFactory.createFactory(JobPersistenceComponentFactory jobPersistenceComponentFactory,
Executor ioExecutor,
RpcService rpcService,
PartialDispatcherServices partialDispatcherServices,
FatalErrorHandler fatalErrorHandler) |
Modifier and Type | Method and Description |
---|---|
DispatcherResourceManagerComponent |
DefaultDispatcherResourceManagerComponentFactory.create(Configuration configuration,
ResourceID resourceId,
Executor ioExecutor,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
BlobServer blobServer,
HeartbeatServices heartbeatServices,
MetricRegistry metricRegistry,
ExecutionGraphInfoStore executionGraphInfoStore,
MetricQueryServiceRetriever metricQueryServiceRetriever,
FatalErrorHandler fatalErrorHandler) |
DispatcherResourceManagerComponent |
DispatcherResourceManagerComponentFactory.create(Configuration configuration,
ResourceID resourceId,
Executor ioExecutor,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
BlobServer blobServer,
HeartbeatServices heartbeatServices,
MetricRegistry metricRegistry,
ExecutionGraphInfoStore executionGraphInfoStore,
MetricQueryServiceRetriever metricQueryServiceRetriever,
FatalErrorHandler fatalErrorHandler) |
Constructor and Description |
---|
JobMaster(RpcService rpcService,
JobMasterId jobMasterId,
JobMasterConfiguration jobMasterConfiguration,
ResourceID resourceId,
JobGraph jobGraph,
HighAvailabilityServices highAvailabilityService,
SlotPoolServiceSchedulerFactory slotPoolServiceSchedulerFactory,
JobManagerSharedServices jobManagerSharedServices,
HeartbeatServices heartbeatServices,
JobManagerJobMetricGroupFactory jobMetricGroupFactory,
OnCompletionActions jobCompletionActions,
FatalErrorHandler fatalErrorHandler,
ClassLoader userCodeLoader,
ShuffleMaster<?> shuffleMaster,
PartitionTrackerFactory partitionTrackerFactory,
ExecutionDeploymentTracker executionDeploymentTracker,
ExecutionDeploymentReconciler.Factory executionDeploymentReconcilerFactory,
long initializationTimestamp) |
Constructor and Description |
---|
DefaultJobMasterServiceFactory(Executor executor,
RpcService rpcService,
JobMasterConfiguration jobMasterConfiguration,
JobGraph jobGraph,
HighAvailabilityServices haServices,
SlotPoolServiceSchedulerFactory slotPoolServiceSchedulerFactory,
JobManagerSharedServices jobManagerSharedServices,
HeartbeatServices heartbeatServices,
JobManagerJobMetricGroupFactory jobManagerJobMetricGroupFactory,
FatalErrorHandler fatalErrorHandler,
ClassLoader userCodeClassloader,
long initializationTimestamp) |
Modifier and Type | Method and Description |
---|---|
RpcService |
MetricRegistryImpl.getMetricQueryServiceRpcService()
Returns the rpc service that the
MetricQueryService runs in. |
Modifier and Type | Method and Description |
---|---|
void |
MetricRegistryImpl.startQueryService(RpcService rpcService,
ResourceID resourceID)
Initializes the MetricQueryService.
|
Modifier and Type | Method and Description |
---|---|
static MetricQueryService |
MetricQueryService.createMetricQueryService(RpcService rpcService,
ResourceID resourceID,
long maximumFrameSize)
Starts the MetricQueryService actor in the given actor system.
|
Constructor and Description |
---|
MetricQueryService(RpcService rpcService,
String endpointId,
long messageSizeLimit) |
Modifier and Type | Method and Description |
---|---|
static RpcService |
MetricUtils.startLocalMetricsRpcService(Configuration configuration,
RpcSystem rpcSystem) |
static RpcService |
MetricUtils.startRemoteMetricsRpcService(Configuration configuration,
String externalAddress,
String bindAddress,
RpcSystem rpcSystem) |
Modifier and Type | Method and Description |
---|---|
protected RpcService |
MiniCluster.createLocalRpcService(Configuration configuration,
RpcSystem rpcSystem)
Factory method to instantiate the local RPC service.
|
protected RpcService |
MiniCluster.createRemoteRpcService(Configuration configuration,
String bindAddress,
int bindPort,
RpcSystem rpcSystem)
Factory method to instantiate the remote RPC service.
|
protected RpcService |
MiniCluster.createRemoteRpcService(Configuration configuration,
String externalAddress,
String externalPortRange,
String bindAddress,
RpcSystem rpcSystem)
Factory method to instantiate the remote RPC service.
|
RpcService |
MiniCluster.RpcServiceFactory.createRpcService() |
RpcService |
MiniCluster.CommonRpcServiceFactory.createRpcService() |
RpcService |
MiniCluster.DedicatedRpcServiceFactory.createRpcService() |
Constructor and Description |
---|
RetryingRegistration(org.slf4j.Logger log,
RpcService rpcService,
String targetName,
Class<G> targetType,
String targetAddress,
F fencingToken,
RetryingRegistrationConfiguration retryingRegistrationConfiguration) |
Modifier and Type | Method and Description |
---|---|
RpcService |
ResourceManagerProcessContext.getRpcService() |
Modifier and Type | Method and Description |
---|---|
static ResourceManagerServiceImpl |
ResourceManagerServiceImpl.create(ResourceManagerFactory<?> resourceManagerFactory,
Configuration configuration,
ResourceID resourceId,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
FatalErrorHandler fatalErrorHandler,
ClusterInformation clusterInformation,
String webInterfaceUrl,
MetricRegistry metricRegistry,
String hostname,
Executor ioExecutor) |
protected abstract ResourceManager<T> |
ResourceManagerFactory.createResourceManager(Configuration configuration,
ResourceID resourceId,
RpcService rpcService,
UUID leaderSessionId,
HeartbeatServices heartbeatServices,
FatalErrorHandler fatalErrorHandler,
ClusterInformation clusterInformation,
String webInterfaceUrl,
ResourceManagerMetricGroup resourceManagerMetricGroup,
ResourceManagerRuntimeServices resourceManagerRuntimeServices,
Executor ioExecutor) |
protected ResourceManager<ResourceID> |
StandaloneResourceManagerFactory.createResourceManager(Configuration configuration,
ResourceID resourceId,
RpcService rpcService,
UUID leaderSessionId,
HeartbeatServices heartbeatServices,
FatalErrorHandler fatalErrorHandler,
ClusterInformation clusterInformation,
String webInterfaceUrl,
ResourceManagerMetricGroup resourceManagerMetricGroup,
ResourceManagerRuntimeServices resourceManagerRuntimeServices,
Executor ioExecutor) |
ResourceManagerProcessContext |
ResourceManagerFactory.createResourceManagerProcessContext(Configuration configuration,
ResourceID resourceId,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
FatalErrorHandler fatalErrorHandler,
ClusterInformation clusterInformation,
String webInterfaceUrl,
MetricRegistry metricRegistry,
String hostname,
Executor ioExecutor) |
Constructor and Description |
---|
ResourceManager(RpcService rpcService,
UUID leaderSessionId,
ResourceID resourceId,
HeartbeatServices heartbeatServices,
SlotManager slotManager,
ResourceManagerPartitionTrackerFactory clusterPartitionTrackerFactory,
JobLeaderIdService jobLeaderIdService,
ClusterInformation clusterInformation,
FatalErrorHandler fatalErrorHandler,
ResourceManagerMetricGroup resourceManagerMetricGroup,
Time rpcTimeout,
Executor ioExecutor) |
ResourceManagerProcessContext(Configuration rmConfig,
ResourceID resourceId,
ResourceManagerRuntimeServicesConfiguration rmRuntimeServicesConfig,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
FatalErrorHandler fatalErrorHandler,
ClusterInformation clusterInformation,
String webInterfaceUrl,
MetricRegistry metricRegistry,
String hostname,
Executor ioExecutor) |
StandaloneResourceManager(RpcService rpcService,
UUID leaderSessionId,
ResourceID resourceId,
HeartbeatServices heartbeatServices,
SlotManager slotManager,
ResourceManagerPartitionTrackerFactory clusterPartitionTrackerFactory,
JobLeaderIdService jobLeaderIdService,
ClusterInformation clusterInformation,
FatalErrorHandler fatalErrorHandler,
ResourceManagerMetricGroup resourceManagerMetricGroup,
Time startupPeriodTime,
Time rpcTimeout,
Executor ioExecutor) |
Modifier and Type | Method and Description |
---|---|
ResourceManager<WorkerType> |
ActiveResourceManagerFactory.createResourceManager(Configuration configuration,
ResourceID resourceId,
RpcService rpcService,
UUID leaderSessionId,
HeartbeatServices heartbeatServices,
FatalErrorHandler fatalErrorHandler,
ClusterInformation clusterInformation,
String webInterfaceUrl,
ResourceManagerMetricGroup resourceManagerMetricGroup,
ResourceManagerRuntimeServices resourceManagerRuntimeServices,
Executor ioExecutor) |
Constructor and Description |
---|
ActiveResourceManager(ResourceManagerDriver<WorkerType> resourceManagerDriver,
Configuration flinkConfig,
RpcService rpcService,
UUID leaderSessionId,
ResourceID resourceId,
HeartbeatServices heartbeatServices,
SlotManager slotManager,
ResourceManagerPartitionTrackerFactory clusterPartitionTrackerFactory,
JobLeaderIdService jobLeaderIdService,
ClusterInformation clusterInformation,
FatalErrorHandler fatalErrorHandler,
ResourceManagerMetricGroup resourceManagerMetricGroup,
ThresholdMeter startWorkerFailureRater,
java.time.Duration retryInterval,
java.time.Duration workerRegistrationTimeout,
Executor ioExecutor) |
Modifier and Type | Method and Description |
---|---|
RpcService |
RpcSystem.RpcServiceBuilder.createAndStart() |
static RpcService |
RpcUtils.createRemoteRpcService(RpcSystem rpcSystem,
Configuration configuration,
String externalAddress,
String externalPortRange,
String bindAddress,
Optional<Integer> bindPort)
Convenient shortcut for constructing a remote RPC Service that takes care of checking for
null and empty optionals.
|
RpcService |
RpcEndpoint.getRpcService()
Gets the endpoint's RPC service.
|
Modifier and Type | Method and Description |
---|---|
static String |
RpcUtils.getHostname(RpcService rpcService)
Returns the hostname onto which the given
RpcService has been bound. |
static void |
RpcUtils.terminateRpcService(RpcService rpcService,
Time timeout)
Shuts the given rpc service down and waits for its termination.
|
static void |
RpcUtils.terminateRpcServices(Time timeout,
RpcService... rpcServices)
Shuts the given rpc services down and waits for their termination.
|
Constructor and Description |
---|
FencedRpcEndpoint(RpcService rpcService,
F fencingToken) |
FencedRpcEndpoint(RpcService rpcService,
String endpointId,
F fencingToken) |
PermanentlyFencedRpcEndpoint(RpcService rpcService,
F fencingToken) |
PermanentlyFencedRpcEndpoint(RpcService rpcService,
String endpointId,
F fencingToken) |
RpcEndpoint(RpcService rpcService)
Initializes the RPC endpoint with a random endpoint id.
|
RpcEndpoint(RpcService rpcService,
String endpointId)
Initializes the RPC endpoint.
|
Modifier and Type | Class and Description |
---|---|
class |
AkkaRpcService
Akka based
RpcService implementation. |
Modifier and Type | Method and Description |
---|---|
TaskManagerRunner.TaskExecutorService |
TaskManagerRunner.TaskExecutorServiceFactory.createTaskExecutor(Configuration configuration,
ResourceID resourceID,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
MetricRegistry metricRegistry,
BlobCacheService blobCacheService,
boolean localCommunicationOnly,
ExternalResourceInfoProvider externalResourceInfoProvider,
WorkingDirectory workingDirectory,
FatalErrorHandler fatalErrorHandler) |
static TaskManagerRunner.TaskExecutorService |
TaskManagerRunner.createTaskExecutorService(Configuration configuration,
ResourceID resourceID,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
MetricRegistry metricRegistry,
BlobCacheService blobCacheService,
boolean localCommunicationOnly,
ExternalResourceInfoProvider externalResourceInfoProvider,
WorkingDirectory workingDirectory,
FatalErrorHandler fatalErrorHandler) |
void |
JobLeaderService.start(String initialOwnerAddress,
RpcService initialRpcService,
HighAvailabilityServices initialHighAvailabilityServices,
JobLeaderListener initialJobLeaderListener)
Start the job leader service with the given services.
|
void |
DefaultJobLeaderService.start(String initialOwnerAddress,
RpcService initialRpcService,
HighAvailabilityServices initialHighAvailabilityServices,
JobLeaderListener initialJobLeaderListener) |
static TaskExecutor |
TaskManagerRunner.startTaskManager(Configuration configuration,
ResourceID resourceID,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
MetricRegistry metricRegistry,
TaskExecutorBlobService taskExecutorBlobService,
boolean localCommunicationOnly,
ExternalResourceInfoProvider externalResourceInfoProvider,
WorkingDirectory workingDirectory,
FatalErrorHandler fatalErrorHandler) |
Constructor and Description |
---|
RpcGatewayRetriever(RpcService rpcService,
Class<T> gatewayType,
java.util.function.Function<UUID,F> fencingTokenMapper,
RetryStrategy retryStrategy) |
RpcMetricQueryServiceRetriever(RpcService rpcService) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.