Uses of Class
org.apache.flink.runtime.entrypoint.ClusterInformation
-
-
Uses of ClusterInformation in org.apache.flink.runtime.minicluster
Methods in org.apache.flink.runtime.minicluster that return ClusterInformation Modifier and Type Method Description ClusterInformation
MiniCluster. getClusterInformation()
-
Uses of ClusterInformation in org.apache.flink.runtime.resourcemanager
Methods in org.apache.flink.runtime.resourcemanager that return ClusterInformation Modifier and Type Method Description ClusterInformation
ResourceManagerProcessContext. getClusterInformation()
Methods in org.apache.flink.runtime.resourcemanager with parameters of type ClusterInformation Modifier and Type Method Description static ResourceManagerServiceImpl
ResourceManagerServiceImpl. create(ResourceManagerFactory<?> resourceManagerFactory, org.apache.flink.configuration.Configuration configuration, ResourceID resourceId, org.apache.flink.runtime.rpc.RpcService rpcService, HighAvailabilityServices highAvailabilityServices, HeartbeatServices heartbeatServices, DelegationTokenManager delegationTokenManager, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, ClusterInformation clusterInformation, String webInterfaceUrl, MetricRegistry metricRegistry, String hostname, Executor ioExecutor)
protected abstract ResourceManager<T>
ResourceManagerFactory. createResourceManager(org.apache.flink.configuration.Configuration configuration, ResourceID resourceId, org.apache.flink.runtime.rpc.RpcService rpcService, UUID leaderSessionId, HeartbeatServices heartbeatServices, DelegationTokenManager delegationTokenManager, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, ClusterInformation clusterInformation, String webInterfaceUrl, ResourceManagerMetricGroup resourceManagerMetricGroup, ResourceManagerRuntimeServices resourceManagerRuntimeServices, Executor ioExecutor)
protected ResourceManager<ResourceID>
StandaloneResourceManagerFactory. createResourceManager(org.apache.flink.configuration.Configuration configuration, ResourceID resourceId, org.apache.flink.runtime.rpc.RpcService rpcService, UUID leaderSessionId, HeartbeatServices heartbeatServices, DelegationTokenManager delegationTokenManager, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, ClusterInformation clusterInformation, String webInterfaceUrl, ResourceManagerMetricGroup resourceManagerMetricGroup, ResourceManagerRuntimeServices resourceManagerRuntimeServices, Executor ioExecutor)
ResourceManagerProcessContext
ResourceManagerFactory. createResourceManagerProcessContext(org.apache.flink.configuration.Configuration configuration, ResourceID resourceId, org.apache.flink.runtime.rpc.RpcService rpcService, HighAvailabilityServices highAvailabilityServices, HeartbeatServices heartbeatServices, DelegationTokenManager delegationTokenManager, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, ClusterInformation clusterInformation, String webInterfaceUrl, MetricRegistry metricRegistry, String hostname, Executor ioExecutor)
Constructors in org.apache.flink.runtime.resourcemanager with parameters of type ClusterInformation Constructor Description ResourceManager(org.apache.flink.runtime.rpc.RpcService rpcService, UUID leaderSessionId, ResourceID resourceId, HeartbeatServices heartbeatServices, DelegationTokenManager delegationTokenManager, SlotManager slotManager, ResourceManagerPartitionTrackerFactory clusterPartitionTrackerFactory, BlocklistHandler.Factory blocklistHandlerFactory, JobLeaderIdService jobLeaderIdService, ClusterInformation clusterInformation, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, ResourceManagerMetricGroup resourceManagerMetricGroup, Duration rpcTimeout, Executor ioExecutor)
ResourceManagerProcessContext(org.apache.flink.configuration.Configuration rmConfig, ResourceID resourceId, ResourceManagerRuntimeServicesConfiguration rmRuntimeServicesConfig, org.apache.flink.runtime.rpc.RpcService rpcService, HighAvailabilityServices highAvailabilityServices, HeartbeatServices heartbeatServices, DelegationTokenManager delegationTokenManager, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, ClusterInformation clusterInformation, String webInterfaceUrl, MetricRegistry metricRegistry, String hostname, Executor ioExecutor)
StandaloneResourceManager(org.apache.flink.runtime.rpc.RpcService rpcService, UUID leaderSessionId, ResourceID resourceId, HeartbeatServices heartbeatServices, DelegationTokenManager delegationTokenManager, SlotManager slotManager, ResourceManagerPartitionTrackerFactory clusterPartitionTrackerFactory, BlocklistHandler.Factory blocklistHandlerFactory, JobLeaderIdService jobLeaderIdService, ClusterInformation clusterInformation, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, ResourceManagerMetricGroup resourceManagerMetricGroup, Duration startupPeriodTime, Duration rpcTimeout, Executor ioExecutor)
-
Uses of ClusterInformation in org.apache.flink.runtime.resourcemanager.active
Methods in org.apache.flink.runtime.resourcemanager.active with parameters of type ClusterInformation Modifier and Type Method Description ResourceManager<WorkerType>
ActiveResourceManagerFactory. createResourceManager(org.apache.flink.configuration.Configuration configuration, ResourceID resourceId, org.apache.flink.runtime.rpc.RpcService rpcService, UUID leaderSessionId, HeartbeatServices heartbeatServices, DelegationTokenManager delegationTokenManager, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, ClusterInformation clusterInformation, String webInterfaceUrl, ResourceManagerMetricGroup resourceManagerMetricGroup, ResourceManagerRuntimeServices resourceManagerRuntimeServices, Executor ioExecutor)
Constructors in org.apache.flink.runtime.resourcemanager.active with parameters of type ClusterInformation Constructor Description ActiveResourceManager(ResourceManagerDriver<WorkerType> resourceManagerDriver, org.apache.flink.configuration.Configuration flinkConfig, org.apache.flink.runtime.rpc.RpcService rpcService, UUID leaderSessionId, ResourceID resourceId, HeartbeatServices heartbeatServices, DelegationTokenManager delegationTokenManager, SlotManager slotManager, ResourceManagerPartitionTrackerFactory clusterPartitionTrackerFactory, BlocklistHandler.Factory blocklistHandlerFactory, JobLeaderIdService jobLeaderIdService, ClusterInformation clusterInformation, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, ResourceManagerMetricGroup resourceManagerMetricGroup, ThresholdMeter startWorkerFailureRater, Duration retryInterval, Duration workerRegistrationTimeout, Duration previousWorkerRecoverTimeout, Executor ioExecutor)
-
Uses of ClusterInformation in org.apache.flink.runtime.taskexecutor
Methods in org.apache.flink.runtime.taskexecutor that return ClusterInformation Modifier and Type Method Description ClusterInformation
TaskExecutorRegistrationSuccess. getClusterInformation()
Gets the cluster information.Constructors in org.apache.flink.runtime.taskexecutor with parameters of type ClusterInformation Constructor Description TaskExecutorRegistrationSuccess(InstanceID registrationId, ResourceID resourceManagerResourceId, ClusterInformation clusterInformation, byte[] initialTokens)
Create a newTaskExecutorRegistrationSuccess
message.
-