public abstract class ActiveResourceManager<WorkerType extends ResourceIDRetrievable> extends ResourceManager<WorkerType>
ResourceManager
implementations which contains some common variables and methods.RpcEndpoint.MainThreadExecutor
限定符和类型 | 字段和说明 |
---|---|
protected int |
defaultMemoryMB |
protected Map<String,String> |
env
The process environment variables.
|
protected org.apache.flink.configuration.Configuration |
flinkClientConfig
Flink configuration uploaded by client.
|
protected org.apache.flink.configuration.Configuration |
flinkConfig
The updated Flink configuration.
|
protected int |
numSlotsPerTaskManager |
protected Collection<ResourceProfile> |
resourceProfilesPerWorker |
protected TaskExecutorProcessSpec |
taskExecutorProcessSpec |
RESOURCE_MANAGER_NAME
log, rpcServer
构造器和说明 |
---|
ActiveResourceManager(org.apache.flink.configuration.Configuration flinkConfig,
Map<String,String> env,
RpcService rpcService,
String resourceManagerEndpointId,
ResourceID resourceId,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
SlotManager slotManager,
JobLeaderIdService jobLeaderIdService,
ClusterInformation clusterInformation,
FatalErrorHandler fatalErrorHandler,
ResourceManagerMetricGroup resourceManagerMetricGroup) |
限定符和类型 | 方法和说明 |
---|---|
protected abstract double |
getCpuCores(org.apache.flink.configuration.Configuration configuration) |
protected CompletableFuture<Void> |
getStopTerminationFutureOrCompletedExceptionally(Throwable exception) |
protected abstract org.apache.flink.configuration.Configuration |
loadClientConfiguration() |
cancelSlotRequest, clearStateAsync, closeJobManagerConnection, closeTaskManagerConnection, deregisterApplication, disconnectJobManager, disconnectTaskManager, getNumberOfRegisteredTaskManagers, getNumberRequiredTaskManagerSlots, grantLeadership, handleError, heartbeatFromJobManager, heartbeatFromTaskManager, initialize, internalDeregisterApplication, jobLeaderLostLeadership, notifySlotAvailable, onFatalError, onStart, onStop, prepareLeadershipAsync, registerJobManager, registerTaskExecutor, releaseResource, removeJob, requestResourceOverview, requestSlot, requestTaskManagerFileUpload, requestTaskManagerInfo, requestTaskManagerInfo, requestTaskManagerMetricQueryServiceAddresses, revokeLeadership, sendSlotReport, setFailUnfulfillableRequest, startNewWorker, startServicesOnLeadership, stopWorker, workerStarted
callAsyncWithoutFencing, getFencingToken, getMainThreadExecutor, getUnfencedMainThreadExecutor, runAsyncWithoutFencing, setFencingToken
callAsync, closeAsync, getAddress, getEndpointId, getHostname, getRpcService, getSelfGateway, getTerminationFuture, internalCallOnStart, internalCallOnStop, isRunning, runAsync, scheduleRunAsync, scheduleRunAsync, start, stop, validateRunsInMainThread
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
getFencingToken
getAddress, getHostname
getDescription
protected final int numSlotsPerTaskManager
protected final TaskExecutorProcessSpec taskExecutorProcessSpec
protected final int defaultMemoryMB
protected final Collection<ResourceProfile> resourceProfilesPerWorker
protected final org.apache.flink.configuration.Configuration flinkConfig
ResourceManager
. For example, TaskManagerOptions.MANAGED_MEMORY_SIZE
.protected final org.apache.flink.configuration.Configuration flinkClientConfig
public ActiveResourceManager(org.apache.flink.configuration.Configuration flinkConfig, Map<String,String> env, RpcService rpcService, String resourceManagerEndpointId, ResourceID resourceId, HighAvailabilityServices highAvailabilityServices, HeartbeatServices heartbeatServices, SlotManager slotManager, JobLeaderIdService jobLeaderIdService, ClusterInformation clusterInformation, FatalErrorHandler fatalErrorHandler, ResourceManagerMetricGroup resourceManagerMetricGroup)
protected CompletableFuture<Void> getStopTerminationFutureOrCompletedExceptionally(@Nullable Throwable exception)
protected abstract org.apache.flink.configuration.Configuration loadClientConfiguration()
protected abstract double getCpuCores(org.apache.flink.configuration.Configuration configuration)
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.