public abstract class SessionClusterEntrypoint extends ClusterEntrypoint
ClusterEntrypoint.ExecutionMode
EXECUTION_MODE, LOG, RUNTIME_FAILURE_RETURN_CODE, STARTUP_FAILURE_RETURN_CODE, SUCCESS_RETURN_CODE
Constructor and Description |
---|
SessionClusterEntrypoint(org.apache.flink.configuration.Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
protected Dispatcher |
createDispatcher(org.apache.flink.configuration.Configuration configuration,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
ResourceManagerGateway resourceManagerGateway,
BlobServer blobServer,
HeartbeatServices heartbeatServices,
JobManagerMetricGroup jobManagerMetricGroup,
String metricQueryServicePath,
ArchivedExecutionGraphStore archivedExecutionGraphStore,
FatalErrorHandler fatalErrorHandler,
String restAddress,
HistoryServerArchivist historyServerArchivist) |
protected DispatcherRestEndpoint |
createRestEndpoint(org.apache.flink.configuration.Configuration configuration,
LeaderGatewayRetriever<DispatcherGateway> dispatcherGatewayRetriever,
LeaderGatewayRetriever<ResourceManagerGateway> resourceManagerGatewayRetriever,
TransientBlobService transientBlobService,
Executor executor,
MetricQueryServiceRetriever metricQueryServiceRetriever,
LeaderElectionService leaderElectionService) |
protected ArchivedExecutionGraphStore |
createSerializableExecutionGraphStore(org.apache.flink.configuration.Configuration configuration,
ScheduledExecutor scheduledExecutor) |
configureFileSystems, createHaServices, createHeartbeatServices, createMetricRegistry, createResourceManager, createRpcService, getRPCPortRange, getTerminationFuture, initializeServices, installSecurityContext, loadConfiguration, onFatalError, parseArguments, runCluster, shutDownAndTerminate, startCluster, startClusterComponents, stopClusterComponents, stopClusterServices
public SessionClusterEntrypoint(org.apache.flink.configuration.Configuration configuration)
protected ArchivedExecutionGraphStore createSerializableExecutionGraphStore(org.apache.flink.configuration.Configuration configuration, ScheduledExecutor scheduledExecutor) throws IOException
createSerializableExecutionGraphStore
in class ClusterEntrypoint
IOException
protected DispatcherRestEndpoint createRestEndpoint(org.apache.flink.configuration.Configuration configuration, LeaderGatewayRetriever<DispatcherGateway> dispatcherGatewayRetriever, LeaderGatewayRetriever<ResourceManagerGateway> resourceManagerGatewayRetriever, TransientBlobService transientBlobService, Executor executor, MetricQueryServiceRetriever metricQueryServiceRetriever, LeaderElectionService leaderElectionService) throws Exception
createRestEndpoint
in class ClusterEntrypoint
Exception
protected Dispatcher createDispatcher(org.apache.flink.configuration.Configuration configuration, RpcService rpcService, HighAvailabilityServices highAvailabilityServices, ResourceManagerGateway resourceManagerGateway, BlobServer blobServer, HeartbeatServices heartbeatServices, JobManagerMetricGroup jobManagerMetricGroup, @Nullable String metricQueryServicePath, ArchivedExecutionGraphStore archivedExecutionGraphStore, FatalErrorHandler fatalErrorHandler, @Nullable String restAddress, HistoryServerArchivist historyServerArchivist) throws Exception
createDispatcher
in class ClusterEntrypoint
Exception
Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.