Package org.apache.flink.configuration

Examples of org.apache.flink.configuration.Configuration


   * @param memorySize
   *            memorySize
   */
  public static void runOnMiniCluster(JobGraph jobGraph, int degreeOfPrallelism, long memorySize) throws Exception  {

    Configuration configuration = jobGraph.getJobConfiguration();

    NepheleMiniCluster exec = new NepheleMiniCluster();
    exec.setMemorySize(memorySize);
    exec.setNumTaskManager(1);
    exec.setTaskManagerNumSlots(degreeOfPrallelism);
View Full Code Here


 
  private final BroadcastVariableManager bcVarManager = new BroadcastVariableManager();
 

  public MockEnvironment(long memorySize, MockInputSplitProvider inputSplitProvider, int bufferSize) {
    this.jobConfiguration = new Configuration();
    this.taskConfiguration = new Configuration();
    this.inputs = new LinkedList<InputGate<Record>>();
    this.outputs = new LinkedList<OutputGate>();

    this.memManager = new DefaultMemoryManager(memorySize, 1);
    this.ioManager = new IOManager(System.getProperty("java.io.tmpdir"));
View Full Code Here

    try {
      this.port = getAvailablePort();
      this.jmServer = RPC.getServer(new MockRPC(), "localhost", this.port, 1);
      this.jmServer.start();
     
      Configuration cfg = new Configuration();
     
      cfg.setString(ConfigConstants.JOB_MANAGER_IPC_ADDRESS_KEY, "localhost");
      cfg.setInteger(ConfigConstants.JOB_MANAGER_IPC_PORT_KEY, this.port);
     
      cfg.setLong(ConfigConstants.TASK_MANAGER_MEMORY_SIZE_KEY, 5);
     
      GlobalConfiguration.includeConfiguration(cfg);
    }
    catch (Throwable t) {
      t.printStackTrace();
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

  @Parameters
  public static Collection<Object[]> getConfigurations() throws 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

    return plan;
  }

  @Parameters
  public static Collection<Object[]> getConfigurations() {
    Configuration config1 = new Configuration();
    config1.setInteger("IterationAllReducer#NoSubtasks", NUM_SUBTASKS);
    return toParameterList(config1);
  }
View Full Code Here

    String[] shipStrategies = { PactCompiler.HINT_SHIP_STRATEGY_REPARTITION_HASH };

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

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

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

    compareResultsByLinesInMemory(EXPECTED, resultPath);
  }

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

public class BlobLibraryCacheManagerTest {

  @Test
  public void testLibraryCacheManagerCleanup(){
    Configuration config = new Configuration();

    config.setLong(ConfigConstants.LIBRARY_CACHE_MANAGER_CLEANUP_INTERVAL, 1);
    GlobalConfiguration.includeConfiguration(config);

    JobID jid = new JobID();
    List<BlobKey> keys = new ArrayList<BlobKey>();
    BlobServer server = null;
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.