Java Code Examples for org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor#DummyComponentMainThreadExecutor
The following examples show how to use
org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor#DummyComponentMainThreadExecutor .
You can vote up the ones you like or vote down the ones you don't like,
and go to the original project or source file by following the links above each example. You may check out the related API usage on the sidebar.
Example 1
Source File: SchedulerImpl.java From Flink-CEPplus with Apache License 2.0 | 5 votes |
@VisibleForTesting public SchedulerImpl( @Nonnull SlotSelectionStrategy slotSelectionStrategy, @Nonnull SlotPool slotPool, @Nonnull Map<SlotSharingGroupId, SlotSharingManager> slotSharingManagers) { this.slotSelectionStrategy = slotSelectionStrategy; this.slotSharingManagers = slotSharingManagers; this.slotPool = slotPool; this.componentMainThreadExecutor = new ComponentMainThreadExecutor.DummyComponentMainThreadExecutor( "Scheduler is not initialized with proper main thread executor. " + "Call to Scheduler.start(...) required."); }
Example 2
Source File: SchedulerImpl.java From flink with Apache License 2.0 | 5 votes |
@VisibleForTesting public SchedulerImpl( @Nonnull SlotSelectionStrategy slotSelectionStrategy, @Nonnull SlotPool slotPool, @Nonnull Map<SlotSharingGroupId, SlotSharingManager> slotSharingManagers) { this.slotSelectionStrategy = slotSelectionStrategy; this.slotSharingManagers = slotSharingManagers; this.slotPool = slotPool; this.componentMainThreadExecutor = new ComponentMainThreadExecutor.DummyComponentMainThreadExecutor( "Scheduler is not initialized with proper main thread executor. " + "Call to Scheduler.start(...) required."); }
Example 3
Source File: SchedulerImpl.java From flink with Apache License 2.0 | 5 votes |
@VisibleForTesting public SchedulerImpl( @Nonnull SlotSelectionStrategy slotSelectionStrategy, @Nonnull SlotPool slotPool, @Nonnull Map<SlotSharingGroupId, SlotSharingManager> slotSharingManagers) { this.slotSelectionStrategy = slotSelectionStrategy; this.slotSharingManagers = slotSharingManagers; this.slotPool = slotPool; this.componentMainThreadExecutor = new ComponentMainThreadExecutor.DummyComponentMainThreadExecutor( "Scheduler is not initialized with proper main thread executor. " + "Call to Scheduler.start(...) required."); this.bulkSlotProvider = new BulkSlotProviderImpl(slotSelectionStrategy, slotPool); }
Example 4
Source File: BulkSlotProviderImpl.java From flink with Apache License 2.0 | 5 votes |
BulkSlotProviderImpl(final SlotSelectionStrategy slotSelectionStrategy, final SlotPool slotPool) { this.slotSelectionStrategy = checkNotNull(slotSelectionStrategy); this.slotPool = checkNotNull(slotPool); this.slotRequestBulkChecker = new PhysicalSlotRequestBulkChecker( this::getAllSlotInfos, SystemClock.getInstance()); this.componentMainThreadExecutor = new ComponentMainThreadExecutor.DummyComponentMainThreadExecutor( "Scheduler is not initialized with proper main thread executor. " + "Call to BulkSlotProvider.start(...) required."); }
Example 5
Source File: ExecutionGraph.java From Flink-CEPplus with Apache License 2.0 | 4 votes |
public ExecutionGraph( JobInformation jobInformation, ScheduledExecutorService futureExecutor, Executor ioExecutor, Time rpcTimeout, RestartStrategy restartStrategy, FailoverStrategy.Factory failoverStrategyFactory, SlotProvider slotProvider, ClassLoader userClassLoader, BlobWriter blobWriter, Time allocationTimeout) throws IOException { checkNotNull(futureExecutor); this.jobInformation = Preconditions.checkNotNull(jobInformation); this.blobWriter = Preconditions.checkNotNull(blobWriter); this.jobInformationOrBlobKey = BlobWriter.serializeAndTryOffload(jobInformation, jobInformation.getJobId(), blobWriter); this.futureExecutor = Preconditions.checkNotNull(futureExecutor); this.ioExecutor = Preconditions.checkNotNull(ioExecutor); this.slotProvider = Preconditions.checkNotNull(slotProvider, "scheduler"); this.userClassLoader = Preconditions.checkNotNull(userClassLoader, "userClassLoader"); this.tasks = new ConcurrentHashMap<>(16); this.intermediateResults = new ConcurrentHashMap<>(16); this.verticesInCreationOrder = new ArrayList<>(16); this.currentExecutions = new ConcurrentHashMap<>(16); this.jobStatusListeners = new CopyOnWriteArrayList<>(); this.executionListeners = new CopyOnWriteArrayList<>(); this.stateTimestamps = new long[JobStatus.values().length]; this.stateTimestamps[JobStatus.CREATED.ordinal()] = System.currentTimeMillis(); this.rpcTimeout = checkNotNull(rpcTimeout); this.allocationTimeout = checkNotNull(allocationTimeout); this.restartStrategy = restartStrategy; this.kvStateLocationRegistry = new KvStateLocationRegistry(jobInformation.getJobId(), getAllVertices()); this.verticesFinished = new AtomicInteger(); this.globalModVersion = 1L; // the failover strategy must be instantiated last, so that the execution graph // is ready by the time the failover strategy sees it this.failoverStrategy = checkNotNull(failoverStrategyFactory.create(this), "null failover strategy"); this.schedulingFuture = null; this.jobMasterMainThreadExecutor = new ComponentMainThreadExecutor.DummyComponentMainThreadExecutor( "ExecutionGraph is not initialized with proper main thread executor. " + "Call to ExecutionGraph.start(...) required."); LOG.info("Job recovers via failover strategy: {}", failoverStrategy.getStrategyName()); }
Example 6
Source File: ExecutionGraph.java From Flink-CEPplus with Apache License 2.0 | 4 votes |
void assertRunningInJobMasterMainThread() { if (!(jobMasterMainThreadExecutor instanceof ComponentMainThreadExecutor.DummyComponentMainThreadExecutor)) { jobMasterMainThreadExecutor.assertRunningInMainThread(); } }
Example 7
Source File: ExecutionGraph.java From flink with Apache License 2.0 | 4 votes |
public ExecutionGraph( JobInformation jobInformation, ScheduledExecutorService futureExecutor, Executor ioExecutor, Time rpcTimeout, RestartStrategy restartStrategy, int maxPriorAttemptsHistoryLength, FailoverStrategy.Factory failoverStrategyFactory, SlotProvider slotProvider, ClassLoader userClassLoader, BlobWriter blobWriter, Time allocationTimeout, PartitionReleaseStrategy.Factory partitionReleaseStrategyFactory, ShuffleMaster<?> shuffleMaster, PartitionTracker partitionTracker, ScheduleMode scheduleMode, boolean allowQueuedScheduling) throws IOException { checkNotNull(futureExecutor); this.jobInformation = Preconditions.checkNotNull(jobInformation); this.blobWriter = Preconditions.checkNotNull(blobWriter); this.scheduleMode = checkNotNull(scheduleMode); this.allowQueuedScheduling = allowQueuedScheduling; this.jobInformationOrBlobKey = BlobWriter.serializeAndTryOffload(jobInformation, jobInformation.getJobId(), blobWriter); this.futureExecutor = Preconditions.checkNotNull(futureExecutor); this.ioExecutor = Preconditions.checkNotNull(ioExecutor); this.slotProviderStrategy = SlotProviderStrategy.from( scheduleMode, slotProvider, allocationTimeout, allowQueuedScheduling); this.userClassLoader = Preconditions.checkNotNull(userClassLoader, "userClassLoader"); this.tasks = new ConcurrentHashMap<>(16); this.intermediateResults = new ConcurrentHashMap<>(16); this.verticesInCreationOrder = new ArrayList<>(16); this.currentExecutions = new ConcurrentHashMap<>(16); this.jobStatusListeners = new CopyOnWriteArrayList<>(); this.stateTimestamps = new long[JobStatus.values().length]; this.stateTimestamps[JobStatus.CREATED.ordinal()] = System.currentTimeMillis(); this.rpcTimeout = checkNotNull(rpcTimeout); this.allocationTimeout = checkNotNull(allocationTimeout); this.partitionReleaseStrategyFactory = checkNotNull(partitionReleaseStrategyFactory); this.restartStrategy = restartStrategy; this.kvStateLocationRegistry = new KvStateLocationRegistry(jobInformation.getJobId(), getAllVertices()); this.verticesFinished = new AtomicInteger(); this.globalModVersion = 1L; // the failover strategy must be instantiated last, so that the execution graph // is ready by the time the failover strategy sees it this.failoverStrategy = checkNotNull(failoverStrategyFactory.create(this), "null failover strategy"); this.maxPriorAttemptsHistoryLength = maxPriorAttemptsHistoryLength; this.schedulingFuture = null; this.jobMasterMainThreadExecutor = new ComponentMainThreadExecutor.DummyComponentMainThreadExecutor( "ExecutionGraph is not initialized with proper main thread executor. " + "Call to ExecutionGraph.start(...) required."); this.shuffleMaster = checkNotNull(shuffleMaster); this.partitionTracker = checkNotNull(partitionTracker); this.resultPartitionAvailabilityChecker = new ExecutionGraphResultPartitionAvailabilityChecker( this::createResultPartitionId, partitionTracker); LOG.info("Job recovers via failover strategy: {}", failoverStrategy.getStrategyName()); }
Example 8
Source File: ExecutionGraph.java From flink with Apache License 2.0 | 4 votes |
void assertRunningInJobMasterMainThread() { if (!(jobMasterMainThreadExecutor instanceof ComponentMainThreadExecutor.DummyComponentMainThreadExecutor)) { jobMasterMainThreadExecutor.assertRunningInMainThread(); } }
Example 9
Source File: ExecutionGraph.java From flink with Apache License 2.0 | 4 votes |
public ExecutionGraph( JobInformation jobInformation, ScheduledExecutorService futureExecutor, Executor ioExecutor, Time rpcTimeout, RestartStrategy restartStrategy, int maxPriorAttemptsHistoryLength, FailoverStrategy.Factory failoverStrategyFactory, SlotProvider slotProvider, ClassLoader userClassLoader, BlobWriter blobWriter, Time allocationTimeout, PartitionReleaseStrategy.Factory partitionReleaseStrategyFactory, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ScheduleMode scheduleMode) throws IOException { this.jobInformation = Preconditions.checkNotNull(jobInformation); this.blobWriter = Preconditions.checkNotNull(blobWriter); this.scheduleMode = checkNotNull(scheduleMode); this.jobInformationOrBlobKey = BlobWriter.serializeAndTryOffload(jobInformation, jobInformation.getJobId(), blobWriter); this.futureExecutor = Preconditions.checkNotNull(futureExecutor); this.ioExecutor = Preconditions.checkNotNull(ioExecutor); this.slotProviderStrategy = SlotProviderStrategy.from( scheduleMode, slotProvider, allocationTimeout); this.userClassLoader = Preconditions.checkNotNull(userClassLoader, "userClassLoader"); this.tasks = new HashMap<>(16); this.intermediateResults = new HashMap<>(16); this.verticesInCreationOrder = new ArrayList<>(16); this.currentExecutions = new HashMap<>(16); this.jobStatusListeners = new ArrayList<>(); this.stateTimestamps = new long[JobStatus.values().length]; this.stateTimestamps[JobStatus.CREATED.ordinal()] = System.currentTimeMillis(); this.rpcTimeout = checkNotNull(rpcTimeout); this.allocationTimeout = checkNotNull(allocationTimeout); this.partitionReleaseStrategyFactory = checkNotNull(partitionReleaseStrategyFactory); this.restartStrategy = restartStrategy; this.kvStateLocationRegistry = new KvStateLocationRegistry(jobInformation.getJobId(), getAllVertices()); this.globalModVersion = 1L; // the failover strategy must be instantiated last, so that the execution graph // is ready by the time the failover strategy sees it this.failoverStrategy = checkNotNull(failoverStrategyFactory.create(this), "null failover strategy"); this.maxPriorAttemptsHistoryLength = maxPriorAttemptsHistoryLength; this.schedulingFuture = null; this.jobMasterMainThreadExecutor = new ComponentMainThreadExecutor.DummyComponentMainThreadExecutor( "ExecutionGraph is not initialized with proper main thread executor. " + "Call to ExecutionGraph.start(...) required."); this.shuffleMaster = checkNotNull(shuffleMaster); this.partitionTracker = checkNotNull(partitionTracker); this.resultPartitionAvailabilityChecker = new ExecutionGraphResultPartitionAvailabilityChecker( this::createResultPartitionId, partitionTracker); }
Example 10
Source File: ExecutionGraph.java From flink with Apache License 2.0 | 4 votes |
void assertRunningInJobMasterMainThread() { if (!(jobMasterMainThreadExecutor instanceof ComponentMainThreadExecutor.DummyComponentMainThreadExecutor)) { jobMasterMainThreadExecutor.assertRunningInMainThread(); } }