Package org.apache.flink.configuration

Examples of org.apache.flink.configuration.Configuration


  public static Collection<Object[]> getConfigurations() throws FileNotFoundException, IOException {

    LinkedList<Configuration> tConfigs = new LinkedList<Configuration>();

    for(int i=1; i <= NUM_PROGRAMS; i++) {
      Configuration config = new Configuration();
      config.setInteger("ProgramId", i);
      tConfigs.add(config);
    }
   
    return toParameterList(tConfigs);
  }
View Full Code Here


  public static Collection<Object[]> getConfigurations() throws FileNotFoundException, IOException {

    LinkedList<Configuration> tConfigs = new LinkedList<Configuration>();

    for(int i=1; i <= NUM_PROGRAMS; i++) {
      Configuration config = new Configuration();
      config.setInteger("ProgramId", i);
      tConfigs.add(config);
    }
   
    return toParameterList(tConfigs);
  }
View Full Code Here

  public static Collection<Object[]> getConfigurations() throws FileNotFoundException, IOException {

    LinkedList<Configuration> tConfigs = new LinkedList<Configuration>();

    for(int i=1; i <= NUM_PROGRAMS; i++) {
      Configuration config = new Configuration();
      config.setInteger("ProgramId", i);
      tConfigs.add(config);
    }
   
    return toParameterList(tConfigs);
  }
View Full Code Here

      addInput(new UniformRecordGenerator(keyCnt, valCnt, false), 0);
      addOutput(this.outList);
     
      // chained combine config
      {
        final TaskConfig combineConfig = new TaskConfig(new Configuration());
 
        // input
        combineConfig.addInputToGroup(0);
        combineConfig.setInputSerializer(serFact, 0);
       
View Full Code Here

      addInput(new UniformRecordGenerator(keyCnt, valCnt, false), 0);
      addOutput(this.outList);
 
      // chained combine config
      {
        final TaskConfig combineConfig = new TaskConfig(new Configuration());
 
        // input
        combineConfig.addInputToGroup(0);
        combineConfig.setInputSerializer(serFact, 0);
       
View Full Code Here

    String sourceTable = "books";
    String targetTable = "newbooks";
    String driverPath = "org.apache.derby.jdbc.EmbeddedDriver";
    String dbUrl = "jdbc:derby:memory:ebookshop";

    Configuration cfg = new Configuration();
    cfg.setString("driver", driverPath);
    cfg.setString("url", dbUrl);
    cfg.setString("query", "insert into " + targetTable + " (id, title, author, price, qty) values (?,?,?,?,?)");
    cfg.setInteger("fields", 5);
    cfg.setClass("type0", IntValue.class);
    cfg.setClass("type1", StringValue.class);
    cfg.setClass("type2", StringValue.class);
    cfg.setClass("type3", FloatValue.class);
    cfg.setClass("type4", IntValue.class);

    jdbcOutputFormat = new JDBCOutputFormat();
    jdbcOutputFormat.configure(cfg);
    jdbcOutputFormat.open(0,1);
View Full Code Here

        throw new RuntimeException("Problem with jar file " + file.getAbsolutePath(), e);
      }
      jobGraph.addJar(new Path(file.getAbsolutePath()));
    }

    Configuration configuration = jobGraph.getJobConfiguration();
    Client client = new Client(new InetSocketAddress(host, port), configuration, getClass().getClassLoader());

    try {
      client.run(jobGraph, true);
    } catch (ProgramInvocationException e) {
View Full Code Here

    };

    for (String localStrategy : localStrategies) {
      for (String shipStrategy : shipStrategies) {

        Configuration config = new Configuration();
        config.setString("CrossTest#LocalStrategy", localStrategy);
        config.setString("CrossTest#ShipStrategy", shipStrategy);
        config.setInteger("CrossTest#NoSubtasks", 4);

        tConfigs.add(config);
      }
    }
View Full Code Here

    compareResultsByLinesInMemory(EXPECTED_RESULT, resultPath);
  }

  @Parameters
  public static Collection<Object[]> getConfigurations() {
    Configuration config = new Configuration();
    config.setInteger("dop", DOP);
    return toParameterList(config);
  }
View Full Code Here

    this.comparators = new ArrayList<TypeComparator<Record>>();
    this.sorters = new ArrayList<UnilateralSortMerger<Record>>();
   
    this.owner = new DummyInvokable();
   
    this.config = new Configuration();
    this.taskConfig = new TaskConfig(this.config);
  }
View Full Code Here

TOP

Related Classes of org.apache.flink.configuration.Configuration

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.