Package org.apache.hadoop.yarn.conf

Examples of org.apache.hadoop.yarn.conf.YarnConfiguration


    assertTrue("Should return an error code", exitCode != 0);
  }

  @Test
  public void testHelpMessage() throws Exception {
    Configuration conf = new YarnConfiguration();
    LogDumper dumper = new LogDumper();
    dumper.setConf(conf);

    int exitCode = dumper.run(new String[]{});
    assertTrue(exitCode == -1);
View Full Code Here


    LOG.info("Starting Mini DFS on path {}", folder);
    Configuration fsConf = new HdfsConfiguration(new Configuration());
    fsConf.set(MiniDFSCluster.HDFS_MINIDFS_BASEDIR, folder.getAbsolutePath());
    dfsCluster = new MiniDFSCluster.Builder(fsConf).numDataNodes(1).build();

    config = new YarnConfiguration(dfsCluster.getFileSystem().getConf());

    if (YarnUtils.isHadoop20()) {
      config.set("yarn.resourcemanager.scheduler.class",
              "org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler");
    } else {
View Full Code Here

  public static void main(String[] args) {
    Thread.setDefaultUncaughtExceptionHandler(new YarnUncaughtExceptionHandler());
    StringUtils.startupShutdownMessage(NodeManager.class, args, LOG);
    NodeManager nodeManager = new NodeManager();
    Configuration conf = new YarnConfiguration();
    setHttpPolicy(conf);
    nodeManager.initAndStartNodeManager(conf, false);
  }
View Full Code Here

    }
  }

  public ApplicationMaster() {
    // Set up the configuration
    conf = new YarnConfiguration();
  }
View Full Code Here

  }

  /**
   */
  public Client() throws Exception  {
    this(new YarnConfiguration());
  }
View Full Code Here

    ApplicationSubmissionContext appContext =
        Mockito.mock(ApplicationSubmissionContext.class);
    Mockito.when(appContext.getUnmanagedAM()).thenReturn(unmanaged);
   
    RMAppAttemptImpl attempt = new RMAppAttemptImpl(attemptId, rmContext, null,
        null, appContext, new YarnConfiguration(), null);
    RMAppAttemptRegistrationEvent event =
        Mockito.mock(RMAppAttemptRegistrationEvent.class);
    Mockito.when(event.getHost()).thenReturn("h");
    Mockito.when(event.getRpcport()).thenReturn(0);
    Mockito.when(event.getTrackingurl()).thenReturn(url);
View Full Code Here

  @Before
  public void setup() throws UnknownHostException {
    Logger rootLogger = LogManager.getRootLogger();
    rootLogger.setLevel(Level.DEBUG);
    ExitUtil.disableSystemExit();
    conf = new YarnConfiguration();
    UserGroupInformation.setConfiguration(conf);
    conf.set(YarnConfiguration.RECOVERY_ENABLED, "true");
    conf.set(YarnConfiguration.RM_STORE, MemoryRMStateStore.class.getName());

    rmAddr = new InetSocketAddress("localhost", 8032);
View Full Code Here

    this.isSecurityEnabled = isSecurityEnabled;
  }
 
  @Before
  public void setUp() throws Exception {
    conf = new YarnConfiguration();
    AuthenticationMethod authMethod = AuthenticationMethod.SIMPLE;
    if (isSecurityEnabled) {
      authMethod = AuthenticationMethod.KERBEROS;
    }
    SecurityUtil.setAuthenticationMethod(authMethod, conf);
View Full Code Here

    return container.getId();
  }

  void testRMAppStateStore(RMStateStoreHelper stateStoreHelper) throws Exception {
    long submitTime = System.currentTimeMillis();
    Configuration conf = new YarnConfiguration();
    RMStateStore store = stateStoreHelper.getRMStateStore();
    TestDispatcher dispatcher = new TestDispatcher();
    store.setRMDispatcher(dispatcher);

    AMRMTokenSecretManager appTokenMgr =
View Full Code Here

      fs.close();
    }

    @Override
    public RMStateStore getRMStateStore() throws Exception {
      YarnConfiguration conf = new YarnConfiguration();
      conf.set(YarnConfiguration.FS_RM_STATE_STORE_URI, workingDirPathURI.toString());
      this.store = new TestFileSystemRMStore(conf);
      return store;
    }
View Full Code Here

TOP

Related Classes of org.apache.hadoop.yarn.conf.YarnConfiguration

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.