Example usage for org.apache.hadoop.mapreduce.v2 MiniMRYarnCluster MiniMRYarnCluster

List of usage examples for org.apache.hadoop.mapreduce.v2 MiniMRYarnCluster MiniMRYarnCluster

Introduction

In this page you can find the example usage for org.apache.hadoop.mapreduce.v2 MiniMRYarnCluster MiniMRYarnCluster.

Prototype

public MiniMRYarnCluster(String testName) 

Source Link

Usage

From source file:com.intropro.prairie.unit.yarn.YarnUnit.java

License:Apache License

@Override
public void init() throws InitUnitException {
    miniMR = new MiniMRYarnCluster(NAME);
    miniMR.init(gatherConfigs());
    miniMR.start();
}

From source file:com.msd.gin.halyard.common.HBaseServerTestInstance.java

License:Apache License

public static synchronized Configuration getInstanceConfig() throws Exception {
    if (conf == null) {
        File zooRoot = File.createTempFile("hbase-zookeeper", "");
        zooRoot.delete();/*from   w w w. j a  v a 2s .c o  m*/
        ZooKeeperServer zookeper = new ZooKeeperServer(zooRoot, zooRoot, 2000);
        ServerCnxnFactory factory = ServerCnxnFactory.createFactory(new InetSocketAddress("localhost", 0),
                5000);
        factory.startup(zookeper);

        YarnConfiguration yconf = new YarnConfiguration();
        String argLine = System.getProperty("argLine");
        if (argLine != null) {
            yconf.set("yarn.app.mapreduce.am.command-opts", argLine.replace("jacoco.exec", "jacocoMR.exec"));
        }
        yconf.setBoolean(MRConfig.MAPREDUCE_MINICLUSTER_CONTROL_RESOURCE_MONITORING, false);
        yconf.setClass(YarnConfiguration.RM_SCHEDULER, FifoScheduler.class, ResourceScheduler.class);
        MiniMRYarnCluster miniCluster = new MiniMRYarnCluster("testCluster");
        miniCluster.init(yconf);
        yconf.setBoolean(MRJobConfig.JOB_UBERTASK_ENABLE, true);
        miniCluster.start();

        File hbaseRoot = File.createTempFile("hbase-root", "");
        hbaseRoot.delete();
        conf = HBaseConfiguration.create(miniCluster.getConfig());
        conf.set(HConstants.HBASE_DIR, hbaseRoot.toURI().toURL().toString());
        conf.setInt(HConstants.ZOOKEEPER_CLIENT_PORT, factory.getLocalPort());
        conf.set("hbase.master.hostname", "localhost");
        conf.set("hbase.regionserver.hostname", "localhost");
        conf.setInt("hbase.master.info.port", -1);
        conf.set("hbase.fs.tmp.dir", new File(System.getProperty("java.io.tmpdir")).toURI().toURL().toString());
        LocalHBaseCluster cluster = new LocalHBaseCluster(conf);
        cluster.startup();
    }
    return conf;
}

From source file:nl.tudelft.graphalytics.mapreducev2.HadoopTestUtils.java

License:Apache License

public void startCluster(String testName) throws IOException {
    mrCluster = new MiniMRYarnCluster(testName);
    mrCluster.init(new Configuration());
    mrCluster.start();//from w  w w.  j a  v a  2 s  .com
}