Package org.apache.flink.runtime.operators.util

Examples of org.apache.flink.runtime.operators.util.TaskConfig


        catch (Exception ex) {
          throw new RuntimeException("Could not instantiate chained task driver.", ex);
        }

        // get the configuration for the task
        final TaskConfig chainedStubConf = config.getChainedStubConfig(i);
        final String taskName = config.getChainedTaskName(i);

        if (i == numChained -1) {
          // last in chain, instantiate the output collector for this task
          previous = getOutputCollector(nepheleTask, chainedStubConf, cl, eventualOutputs, chainedStubConf.getNumOutputs());
        }

        ct.setup(chainedStubConf, taskName, previous, nepheleTask, cl);
        chainedTasksTarget.add(0, ct);
View Full Code Here


  @Test
  public void testOutputFormatVertex() {
    try {
      final TestingOutputFormat outputFormat = new TestingOutputFormat();
      final OutputFormatVertex of = new OutputFormatVertex("Name");
      new TaskConfig(of.getConfiguration()).setStubWrapper(new UserCodeObjectWrapper<OutputFormat<?>>(outputFormat));
      final ClassLoader cl = getClass().getClassLoader();
     
      try {
        of.initializeOnMaster(cl);
        fail("Did not throw expected exception.");
View Full Code Here

  @Test
  public void testInputFormatVertex() {
    try {
      final TestInputFormat inputFormat = new TestInputFormat();
      final InputFormatVertex vertex = new InputFormatVertex("Name");
      new TaskConfig(vertex.getConfiguration()).setStubWrapper(new UserCodeObjectWrapper<InputFormat<?, ?>>(inputFormat));
     
      final ClassLoader cl = getClass().getClassLoader();
     
      vertex.initializeOnMaster(cl);
      InputSplit[] splits = vertex.getInputSplitSource().createInputSplits(77);
View Full Code Here

TOP

Related Classes of org.apache.flink.runtime.operators.util.TaskConfig

Copyright © 2018 www.massapicom. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.