org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo Java Examples
The following examples show how to use
org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo.
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: RocksDBStateBackendConfigTest.java From Flink-CEPplus with Apache License 2.0 | 5 votes |
static Environment getMockEnvironment(File... tempDirs) { final String[] tempDirStrings = new String[tempDirs.length]; for (int i = 0; i < tempDirs.length; i++) { tempDirStrings[i] = tempDirs[i].getAbsolutePath(); } IOManager ioMan = mock(IOManager.class); when(ioMan.getSpillingDirectories()).thenReturn(tempDirs); Environment env = mock(Environment.class); when(env.getJobID()).thenReturn(new JobID()); when(env.getUserClassLoader()).thenReturn(RocksDBStateBackendConfigTest.class.getClassLoader()); when(env.getIOManager()).thenReturn(ioMan); when(env.getTaskKvStateRegistry()).thenReturn(new KvStateRegistry().createTaskRegistry(new JobID(), new JobVertexID())); TaskInfo taskInfo = mock(TaskInfo.class); when(env.getTaskInfo()).thenReturn(taskInfo); when(taskInfo.getIndexOfThisSubtask()).thenReturn(0); TaskManagerRuntimeInfo tmInfo = new TestingTaskManagerRuntimeInfo(new Configuration(), tempDirStrings); when(env.getTaskManagerInfo()).thenReturn(tmInfo); TestTaskStateManager taskStateManager = new TestTaskStateManager(); when(env.getTaskStateManager()).thenReturn(taskStateManager); return env; }
Example #2
Source File: RocksDBStateBackendConfigTest.java From flink with Apache License 2.0 | 5 votes |
static Environment getMockEnvironment(File... tempDirs) { final String[] tempDirStrings = new String[tempDirs.length]; for (int i = 0; i < tempDirs.length; i++) { tempDirStrings[i] = tempDirs[i].getAbsolutePath(); } IOManager ioMan = mock(IOManager.class); when(ioMan.getSpillingDirectories()).thenReturn(tempDirs); Environment env = mock(Environment.class); when(env.getJobID()).thenReturn(new JobID()); when(env.getUserClassLoader()).thenReturn(RocksDBStateBackendConfigTest.class.getClassLoader()); when(env.getIOManager()).thenReturn(ioMan); when(env.getTaskKvStateRegistry()).thenReturn(new KvStateRegistry().createTaskRegistry(new JobID(), new JobVertexID())); TaskInfo taskInfo = mock(TaskInfo.class); when(env.getTaskInfo()).thenReturn(taskInfo); when(taskInfo.getIndexOfThisSubtask()).thenReturn(0); TaskManagerRuntimeInfo tmInfo = new TestingTaskManagerRuntimeInfo(new Configuration(), tempDirStrings); when(env.getTaskManagerInfo()).thenReturn(tmInfo); TestTaskStateManager taskStateManager = new TestTaskStateManager(); when(env.getTaskStateManager()).thenReturn(taskStateManager); return env; }
Example #3
Source File: TestTaskContext.java From flink with Apache License 2.0 | 4 votes |
@Override public TaskManagerRuntimeInfo getTaskManagerInfo() { return this.taskManageInfo; }
Example #4
Source File: MockEnvironmentBuilder.java From flink with Apache License 2.0 | 4 votes |
public MockEnvironmentBuilder setTaskManagerRuntimeInfo(TaskManagerRuntimeInfo taskManagerRuntimeInfo){ this.taskManagerRuntimeInfo = taskManagerRuntimeInfo; return this; }
Example #5
Source File: DummyEnvironment.java From flink with Apache License 2.0 | 4 votes |
@Override public TaskManagerRuntimeInfo getTaskManagerInfo() { return new TestingTaskManagerRuntimeInfo(); }
Example #6
Source File: BinaryOperatorTestBase.java From flink with Apache License 2.0 | 4 votes |
@Override public TaskManagerRuntimeInfo getTaskManagerInfo() { return this.taskManageInfo; }
Example #7
Source File: JvmExitOnFatalErrorTest.java From flink with Apache License 2.0 | 4 votes |
public static void main(String[] args) throws Exception { System.err.println("creating task"); // we suppress process exits via errors here to not // have a test that exits accidentally due to a programming error try { final Configuration taskManagerConfig = new Configuration(); taskManagerConfig.setBoolean(TaskManagerOptions.KILL_ON_OUT_OF_MEMORY, true); final JobID jid = new JobID(); final AllocationID allocationID = new AllocationID(); final JobVertexID jobVertexId = new JobVertexID(); final ExecutionAttemptID executionAttemptID = new ExecutionAttemptID(); final AllocationID slotAllocationId = new AllocationID(); final SerializedValue<ExecutionConfig> execConfig = new SerializedValue<>(new ExecutionConfig()); final JobInformation jobInformation = new JobInformation( jid, "Test Job", execConfig, new Configuration(), Collections.emptyList(), Collections.emptyList()); final TaskInformation taskInformation = new TaskInformation( jobVertexId, "Test Task", 1, 1, OomInvokable.class.getName(), new Configuration()); final MemoryManager memoryManager = new MemoryManager(1024 * 1024, 1); final IOManager ioManager = new IOManagerAsync(); final ShuffleEnvironment<?, ?> shuffleEnvironment = new NettyShuffleEnvironmentBuilder().build(); final TaskManagerRuntimeInfo tmInfo = TaskManagerConfiguration.fromConfiguration(taskManagerConfig); final Executor executor = Executors.newCachedThreadPool(); BlobCacheService blobService = new BlobCacheService(mock(PermanentBlobCache.class), mock(TransientBlobCache.class)); final TaskLocalStateStore localStateStore = new TaskLocalStateStoreImpl( jid, allocationID, jobVertexId, 0, TestLocalRecoveryConfig.disabled(), executor); final TaskStateManager slotStateManager = new TaskStateManagerImpl( jid, executionAttemptID, localStateStore, null, mock(CheckpointResponder.class)); Task task = new Task( jobInformation, taskInformation, executionAttemptID, slotAllocationId, 0, // subtaskIndex 0, // attemptNumber Collections.<ResultPartitionDeploymentDescriptor>emptyList(), Collections.<InputGateDeploymentDescriptor>emptyList(), 0, // targetSlotNumber memoryManager, ioManager, shuffleEnvironment, new KvStateService(new KvStateRegistry(), null, null), new BroadcastVariableManager(), new TaskEventDispatcher(), slotStateManager, new NoOpTaskManagerActions(), new NoOpInputSplitProvider(), new NoOpCheckpointResponder(), new TestGlobalAggregateManager(), blobService, new BlobLibraryCacheManager( blobService.getPermanentBlobService(), FlinkUserCodeClassLoaders.ResolveOrder.CHILD_FIRST, new String[0]), new FileCache(tmInfo.getTmpDirectories(), blobService.getPermanentBlobService()), tmInfo, UnregisteredMetricGroups.createUnregisteredTaskMetricGroup(), new NoOpResultPartitionConsumableNotifier(), new NoOpPartitionProducerStateChecker(), executor); System.err.println("starting task thread"); task.startTaskThread(); } catch (Throwable t) { System.err.println("ERROR STARTING TASK"); t.printStackTrace(); } System.err.println("parking the main thread"); CommonTestUtils.blockForeverNonInterruptibly(); }
Example #8
Source File: StreamTaskTerminationTest.java From flink with Apache License 2.0 | 4 votes |
/** * FLINK-6833 * * <p>Tests that a finished stream task cannot be failed by an asynchronous checkpointing operation after * the stream task has stopped running. */ @Test public void testConcurrentAsyncCheckpointCannotFailFinishedStreamTask() throws Exception { final Configuration taskConfiguration = new Configuration(); final StreamConfig streamConfig = new StreamConfig(taskConfiguration); final NoOpStreamOperator<Long> noOpStreamOperator = new NoOpStreamOperator<>(); final StateBackend blockingStateBackend = new BlockingStateBackend(); streamConfig.setStreamOperator(noOpStreamOperator); streamConfig.setOperatorID(new OperatorID()); streamConfig.setStateBackend(blockingStateBackend); final long checkpointId = 0L; final long checkpointTimestamp = 0L; final JobInformation jobInformation = new JobInformation( new JobID(), "Test Job", new SerializedValue<>(new ExecutionConfig()), new Configuration(), Collections.emptyList(), Collections.emptyList()); final TaskInformation taskInformation = new TaskInformation( new JobVertexID(), "Test Task", 1, 1, BlockingStreamTask.class.getName(), taskConfiguration); final TaskManagerRuntimeInfo taskManagerRuntimeInfo = new TestingTaskManagerRuntimeInfo(); final ShuffleEnvironment<?, ?> shuffleEnvironment = new NettyShuffleEnvironmentBuilder().build(); BlobCacheService blobService = new BlobCacheService(mock(PermanentBlobCache.class), mock(TransientBlobCache.class)); final Task task = new Task( jobInformation, taskInformation, new ExecutionAttemptID(), new AllocationID(), 0, 0, Collections.<ResultPartitionDeploymentDescriptor>emptyList(), Collections.<InputGateDeploymentDescriptor>emptyList(), 0, new MemoryManager(32L * 1024L, 1), new IOManagerAsync(), shuffleEnvironment, new KvStateService(new KvStateRegistry(), null, null), mock(BroadcastVariableManager.class), new TaskEventDispatcher(), new TestTaskStateManager(), mock(TaskManagerActions.class), mock(InputSplitProvider.class), mock(CheckpointResponder.class), new TestGlobalAggregateManager(), blobService, new BlobLibraryCacheManager( blobService.getPermanentBlobService(), FlinkUserCodeClassLoaders.ResolveOrder.CHILD_FIRST, new String[0]), mock(FileCache.class), taskManagerRuntimeInfo, UnregisteredMetricGroups.createUnregisteredTaskMetricGroup(), new NoOpResultPartitionConsumableNotifier(), mock(PartitionProducerStateChecker.class), Executors.directExecutor()); CompletableFuture<Void> taskRun = CompletableFuture.runAsync( () -> task.run(), TestingUtils.defaultExecutor()); // wait until the stream task started running RUN_LATCH.await(); // trigger a checkpoint task.triggerCheckpointBarrier(checkpointId, checkpointTimestamp, CheckpointOptions.forCheckpointWithDefaultLocation(), false); // wait until the task has completed execution taskRun.get(); // check that no failure occurred if (task.getFailureCause() != null) { throw new Exception("Task failed", task.getFailureCause()); } // check that we have entered the finished state assertEquals(ExecutionState.FINISHED, task.getExecutionState()); }
Example #9
Source File: StreamMockEnvironment.java From flink with Apache License 2.0 | 4 votes |
@Override public TaskManagerRuntimeInfo getTaskManagerInfo() { return this.taskManagerRuntimeInfo; }
Example #10
Source File: StreamMockEnvironment.java From flink with Apache License 2.0 | 4 votes |
public void setTaskManagerInfo(TaskManagerRuntimeInfo taskManagerRuntimeInfo) { this.taskManagerRuntimeInfo = taskManagerRuntimeInfo; }
Example #11
Source File: SavepointEnvironment.java From flink with Apache License 2.0 | 4 votes |
@Override public TaskManagerRuntimeInfo getTaskManagerInfo() { return new SavepointTaskManagerRuntimeInfo(getIOManager()); }
Example #12
Source File: BatchTask.java From flink with Apache License 2.0 | 4 votes |
@Override public TaskManagerRuntimeInfo getTaskManagerInfo() { return getEnvironment().getTaskManagerInfo(); }
Example #13
Source File: MockEnvironment.java From flink with Apache License 2.0 | 4 votes |
@Override public TaskManagerRuntimeInfo getTaskManagerInfo() { return this.taskManagerRuntimeInfo; }
Example #14
Source File: DriverTestBase.java From flink with Apache License 2.0 | 4 votes |
@Override public TaskManagerRuntimeInfo getTaskManagerInfo() { return this.taskManageInfo; }
Example #15
Source File: UnaryOperatorTestBase.java From flink with Apache License 2.0 | 4 votes |
@Override public TaskManagerRuntimeInfo getTaskManagerInfo() { return this.taskManageInfo; }
Example #16
Source File: MockEnvironment.java From flink with Apache License 2.0 | 4 votes |
protected MockEnvironment( JobID jobID, JobVertexID jobVertexID, String taskName, MockInputSplitProvider inputSplitProvider, int bufferSize, Configuration taskConfiguration, ExecutionConfig executionConfig, IOManager ioManager, TaskStateManager taskStateManager, GlobalAggregateManager aggregateManager, int maxParallelism, int parallelism, int subtaskIndex, ClassLoader userCodeClassLoader, TaskMetricGroup taskMetricGroup, TaskManagerRuntimeInfo taskManagerRuntimeInfo, MemoryManager memManager, ExternalResourceInfoProvider externalResourceInfoProvider) { this.jobID = jobID; this.jobVertexID = jobVertexID; this.taskInfo = new TaskInfo(taskName, maxParallelism, subtaskIndex, parallelism, 0); this.jobConfiguration = new Configuration(); this.taskConfiguration = taskConfiguration; this.inputs = new LinkedList<>(); this.outputs = new LinkedList<ResultPartitionWriter>(); this.memManager = memManager; this.ioManager = ioManager; this.taskManagerRuntimeInfo = taskManagerRuntimeInfo; this.executionConfig = executionConfig; this.inputSplitProvider = inputSplitProvider; this.bufferSize = bufferSize; this.accumulatorRegistry = new AccumulatorRegistry(jobID, getExecutionId()); this.kvStateRegistry = new KvStateRegistry(); this.taskKvStateRegistry = kvStateRegistry.createTaskRegistry(jobID, getJobVertexId()); this.userCodeClassLoader = Preconditions.checkNotNull(userCodeClassLoader); this.taskStateManager = Preconditions.checkNotNull(taskStateManager); this.aggregateManager = Preconditions.checkNotNull(aggregateManager); this.taskMetricGroup = taskMetricGroup; this.externalResourceInfoProvider = Preconditions.checkNotNull(externalResourceInfoProvider); }
Example #17
Source File: MockEnvironment.java From flink with Apache License 2.0 | 4 votes |
@Override public TaskManagerRuntimeInfo getTaskManagerInfo() { return this.taskManagerRuntimeInfo; }
Example #18
Source File: MockEnvironmentBuilder.java From flink with Apache License 2.0 | 4 votes |
public MockEnvironmentBuilder setTaskManagerRuntimeInfo(TaskManagerRuntimeInfo taskManagerRuntimeInfo) { this.taskManagerRuntimeInfo = taskManagerRuntimeInfo; return this; }
Example #19
Source File: DummyEnvironment.java From flink with Apache License 2.0 | 4 votes |
@Override public TaskManagerRuntimeInfo getTaskManagerInfo() { return new TestingTaskManagerRuntimeInfo(); }
Example #20
Source File: BinaryOperatorTestBase.java From flink with Apache License 2.0 | 4 votes |
@Override public TaskManagerRuntimeInfo getTaskManagerInfo() { return this.taskManageInfo; }
Example #21
Source File: JvmExitOnFatalErrorTest.java From flink with Apache License 2.0 | 4 votes |
public static void main(String[] args) throws Exception { System.err.println("creating task"); // we suppress process exits via errors here to not // have a test that exits accidentally due to a programming error try { final Configuration taskManagerConfig = new Configuration(); taskManagerConfig.setBoolean(TaskManagerOptions.KILL_ON_OUT_OF_MEMORY, true); final JobID jid = new JobID(); final AllocationID allocationID = new AllocationID(); final JobVertexID jobVertexId = new JobVertexID(); final ExecutionAttemptID executionAttemptID = new ExecutionAttemptID(); final AllocationID slotAllocationId = new AllocationID(); final SerializedValue<ExecutionConfig> execConfig = new SerializedValue<>(new ExecutionConfig()); final JobInformation jobInformation = new JobInformation( jid, "Test Job", execConfig, new Configuration(), Collections.emptyList(), Collections.emptyList()); final TaskInformation taskInformation = new TaskInformation( jobVertexId, "Test Task", 1, 1, OomInvokable.class.getName(), new Configuration()); final MemoryManager memoryManager = MemoryManagerBuilder.newBuilder().setMemorySize(1024 * 1024).build(); final IOManager ioManager = new IOManagerAsync(); final ShuffleEnvironment<?, ?> shuffleEnvironment = new NettyShuffleEnvironmentBuilder().build(); final Configuration copiedConf = new Configuration(taskManagerConfig); final TaskManagerRuntimeInfo tmInfo = TaskManagerConfiguration .fromConfiguration( taskManagerConfig, TaskExecutorResourceUtils.resourceSpecFromConfigForLocalExecution(copiedConf), InetAddress.getLoopbackAddress().getHostAddress()); final Executor executor = Executors.newCachedThreadPool(); final TaskLocalStateStore localStateStore = new TaskLocalStateStoreImpl( jid, allocationID, jobVertexId, 0, TestLocalRecoveryConfig.disabled(), executor); final TaskStateManager slotStateManager = new TaskStateManagerImpl( jid, executionAttemptID, localStateStore, null, mock(CheckpointResponder.class)); Task task = new Task( jobInformation, taskInformation, executionAttemptID, slotAllocationId, 0, // subtaskIndex 0, // attemptNumber Collections.<ResultPartitionDeploymentDescriptor>emptyList(), Collections.<InputGateDeploymentDescriptor>emptyList(), 0, // targetSlotNumber memoryManager, ioManager, shuffleEnvironment, new KvStateService(new KvStateRegistry(), null, null), new BroadcastVariableManager(), new TaskEventDispatcher(), ExternalResourceInfoProvider.NO_EXTERNAL_RESOURCES, slotStateManager, new NoOpTaskManagerActions(), new NoOpInputSplitProvider(), NoOpCheckpointResponder.INSTANCE, new NoOpTaskOperatorEventGateway(), new TestGlobalAggregateManager(), TestingClassLoaderLease.newBuilder().build(), new FileCache(tmInfo.getTmpDirectories(), VoidPermanentBlobService.INSTANCE), tmInfo, UnregisteredMetricGroups.createUnregisteredTaskMetricGroup(), new NoOpResultPartitionConsumableNotifier(), new NoOpPartitionProducerStateChecker(), executor); System.err.println("starting task thread"); task.startTaskThread(); } catch (Throwable t) { System.err.println("ERROR STARTING TASK"); t.printStackTrace(); } System.err.println("parking the main thread"); CommonTestUtils.blockForeverNonInterruptibly(); }
Example #22
Source File: StreamTaskTerminationTest.java From flink with Apache License 2.0 | 4 votes |
/** * FLINK-6833 * * <p>Tests that a finished stream task cannot be failed by an asynchronous checkpointing operation after * the stream task has stopped running. */ @Test public void testConcurrentAsyncCheckpointCannotFailFinishedStreamTask() throws Exception { final Configuration taskConfiguration = new Configuration(); final StreamConfig streamConfig = new StreamConfig(taskConfiguration); final NoOpStreamOperator<Long> noOpStreamOperator = new NoOpStreamOperator<>(); final StateBackend blockingStateBackend = new BlockingStateBackend(); streamConfig.setStreamOperator(noOpStreamOperator); streamConfig.setOperatorID(new OperatorID()); streamConfig.setStateBackend(blockingStateBackend); final long checkpointId = 0L; final long checkpointTimestamp = 0L; final JobInformation jobInformation = new JobInformation( new JobID(), "Test Job", new SerializedValue<>(new ExecutionConfig()), new Configuration(), Collections.emptyList(), Collections.emptyList()); final TaskInformation taskInformation = new TaskInformation( new JobVertexID(), "Test Task", 1, 1, BlockingStreamTask.class.getName(), taskConfiguration); final TaskManagerRuntimeInfo taskManagerRuntimeInfo = new TestingTaskManagerRuntimeInfo(); final ShuffleEnvironment<?, ?> shuffleEnvironment = new NettyShuffleEnvironmentBuilder().build(); final Task task = new Task( jobInformation, taskInformation, new ExecutionAttemptID(), new AllocationID(), 0, 0, Collections.<ResultPartitionDeploymentDescriptor>emptyList(), Collections.<InputGateDeploymentDescriptor>emptyList(), 0, MemoryManagerBuilder.newBuilder().setMemorySize(32L * 1024L).build(), new IOManagerAsync(), shuffleEnvironment, new KvStateService(new KvStateRegistry(), null, null), mock(BroadcastVariableManager.class), new TaskEventDispatcher(), ExternalResourceInfoProvider.NO_EXTERNAL_RESOURCES, new TestTaskStateManager(), mock(TaskManagerActions.class), mock(InputSplitProvider.class), mock(CheckpointResponder.class), new NoOpTaskOperatorEventGateway(), new TestGlobalAggregateManager(), TestingClassLoaderLease.newBuilder().build(), mock(FileCache.class), taskManagerRuntimeInfo, UnregisteredMetricGroups.createUnregisteredTaskMetricGroup(), new NoOpResultPartitionConsumableNotifier(), mock(PartitionProducerStateChecker.class), Executors.directExecutor()); CompletableFuture<Void> taskRun = CompletableFuture.runAsync( () -> task.run(), TestingUtils.defaultExecutor()); // wait until the stream task started running RUN_LATCH.await(); // trigger a checkpoint task.triggerCheckpointBarrier(checkpointId, checkpointTimestamp, CheckpointOptions.forCheckpointWithDefaultLocation(), false); // wait until the task has completed execution taskRun.get(); // check that no failure occurred if (task.getFailureCause() != null) { throw new Exception("Task failed", task.getFailureCause()); } // check that we have entered the finished state assertEquals(ExecutionState.FINISHED, task.getExecutionState()); }
Example #23
Source File: StreamMockEnvironment.java From flink with Apache License 2.0 | 4 votes |
@Override public TaskManagerRuntimeInfo getTaskManagerInfo() { return this.taskManagerRuntimeInfo; }
Example #24
Source File: StreamMockEnvironment.java From flink with Apache License 2.0 | 4 votes |
public void setTaskManagerInfo(TaskManagerRuntimeInfo taskManagerRuntimeInfo) { this.taskManagerRuntimeInfo = taskManagerRuntimeInfo; }
Example #25
Source File: UnaryOperatorTestBase.java From flink with Apache License 2.0 | 4 votes |
@Override public TaskManagerRuntimeInfo getTaskManagerInfo() { return this.taskManageInfo; }
Example #26
Source File: BatchTask.java From Flink-CEPplus with Apache License 2.0 | 4 votes |
@Override public TaskManagerRuntimeInfo getTaskManagerInfo() { return getEnvironment().getTaskManagerInfo(); }
Example #27
Source File: TestTaskContext.java From Flink-CEPplus with Apache License 2.0 | 4 votes |
@Override public TaskManagerRuntimeInfo getTaskManagerInfo() { return this.taskManageInfo; }
Example #28
Source File: DriverTestBase.java From Flink-CEPplus with Apache License 2.0 | 4 votes |
@Override public TaskManagerRuntimeInfo getTaskManagerInfo() { return this.taskManageInfo; }
Example #29
Source File: UnaryOperatorTestBase.java From Flink-CEPplus with Apache License 2.0 | 4 votes |
@Override public TaskManagerRuntimeInfo getTaskManagerInfo() { return this.taskManageInfo; }
Example #30
Source File: MockEnvironment.java From Flink-CEPplus with Apache License 2.0 | 4 votes |
protected MockEnvironment( JobID jobID, JobVertexID jobVertexID, String taskName, long memorySize, MockInputSplitProvider inputSplitProvider, int bufferSize, Configuration taskConfiguration, ExecutionConfig executionConfig, TaskStateManager taskStateManager, GlobalAggregateManager aggregateManager, int maxParallelism, int parallelism, int subtaskIndex, ClassLoader userCodeClassLoader, TaskMetricGroup taskMetricGroup, TaskManagerRuntimeInfo taskManagerRuntimeInfo) { this.jobID = jobID; this.jobVertexID = jobVertexID; this.taskInfo = new TaskInfo(taskName, maxParallelism, subtaskIndex, parallelism, 0); this.jobConfiguration = new Configuration(); this.taskConfiguration = taskConfiguration; this.inputs = new LinkedList<InputGate>(); this.outputs = new LinkedList<ResultPartitionWriter>(); this.memManager = new MemoryManager(memorySize, 1); this.ioManager = new IOManagerAsync(); this.taskManagerRuntimeInfo = taskManagerRuntimeInfo; this.executionConfig = executionConfig; this.inputSplitProvider = inputSplitProvider; this.bufferSize = bufferSize; this.accumulatorRegistry = new AccumulatorRegistry(jobID, getExecutionId()); KvStateRegistry registry = new KvStateRegistry(); this.kvStateRegistry = registry.createTaskRegistry(jobID, getJobVertexId()); this.userCodeClassLoader = Preconditions.checkNotNull(userCodeClassLoader); this.taskStateManager = Preconditions.checkNotNull(taskStateManager); this.aggregateManager = Preconditions.checkNotNull(aggregateManager); this.taskMetricGroup = taskMetricGroup; }