Uses of Interface
org.apache.flink.runtime.blocklist.BlocklistHandler.Factory
-
-
Uses of BlocklistHandler.Factory in org.apache.flink.runtime.blocklist
Classes in org.apache.flink.runtime.blocklist that implement BlocklistHandler.Factory Modifier and Type Class Description static class
DefaultBlocklistHandler.Factory
The factory to instantiateDefaultBlocklistHandler
.static class
NoOpBlocklistHandler.Factory
The factory to instantiateNoOpBlocklistHandler
.Methods in org.apache.flink.runtime.blocklist that return BlocklistHandler.Factory Modifier and Type Method Description static BlocklistHandler.Factory
BlocklistUtils. loadBlocklistHandlerFactory(Configuration configuration)
-
Uses of BlocklistHandler.Factory in org.apache.flink.runtime.jobmaster
Constructors in org.apache.flink.runtime.jobmaster with parameters of type BlocklistHandler.Factory Constructor Description JobMaster(RpcService rpcService, JobMasterId jobMasterId, JobMasterConfiguration jobMasterConfiguration, ResourceID resourceId, ExecutionPlan executionPlan, 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, BlocklistHandler.Factory blocklistHandlerFactory, Collection<FailureEnricher> failureEnrichers, long initializationTimestamp)
-
Uses of BlocklistHandler.Factory in org.apache.flink.runtime.resourcemanager
Constructors in org.apache.flink.runtime.resourcemanager with parameters of type BlocklistHandler.Factory Constructor Description ResourceManager(RpcService rpcService, UUID leaderSessionId, ResourceID resourceId, HeartbeatServices heartbeatServices, DelegationTokenManager delegationTokenManager, SlotManager slotManager, ResourceManagerPartitionTrackerFactory clusterPartitionTrackerFactory, BlocklistHandler.Factory blocklistHandlerFactory, JobLeaderIdService jobLeaderIdService, ClusterInformation clusterInformation, FatalErrorHandler fatalErrorHandler, ResourceManagerMetricGroup resourceManagerMetricGroup, Duration rpcTimeout, Executor ioExecutor)
StandaloneResourceManager(RpcService rpcService, UUID leaderSessionId, ResourceID resourceId, HeartbeatServices heartbeatServices, DelegationTokenManager delegationTokenManager, SlotManager slotManager, ResourceManagerPartitionTrackerFactory clusterPartitionTrackerFactory, BlocklistHandler.Factory blocklistHandlerFactory, JobLeaderIdService jobLeaderIdService, ClusterInformation clusterInformation, FatalErrorHandler fatalErrorHandler, ResourceManagerMetricGroup resourceManagerMetricGroup, Duration startupPeriodTime, Duration rpcTimeout, Executor ioExecutor)
-
Uses of BlocklistHandler.Factory in org.apache.flink.runtime.resourcemanager.active
Constructors in org.apache.flink.runtime.resourcemanager.active with parameters of type BlocklistHandler.Factory Constructor Description ActiveResourceManager(ResourceManagerDriver<WorkerType> resourceManagerDriver, Configuration flinkConfig, RpcService rpcService, UUID leaderSessionId, ResourceID resourceId, HeartbeatServices heartbeatServices, DelegationTokenManager delegationTokenManager, SlotManager slotManager, ResourceManagerPartitionTrackerFactory clusterPartitionTrackerFactory, BlocklistHandler.Factory blocklistHandlerFactory, JobLeaderIdService jobLeaderIdService, ClusterInformation clusterInformation, FatalErrorHandler fatalErrorHandler, ResourceManagerMetricGroup resourceManagerMetricGroup, ThresholdMeter startWorkerFailureRater, Duration retryInterval, Duration workerRegistrationTimeout, Duration previousWorkerRecoverTimeout, Executor ioExecutor)
-