Package org.apache.hadoop.corona

Examples of org.apache.hadoop.corona.CoronaConf


  /**
   * Main service loop.  Will stay in this loop forever.
   */
  private void heartbeatToClusterManager() throws IOException {
    CoronaConf coronaConf = new CoronaConf(fConf);
    int numCpu = resourceCalculatorPlugin.getNumProcessors();
    if (numCpu == ResourceCalculatorPlugin.UNAVAILABLE) {
      numCpu = 1;
    }
    int totalMemoryMB = (int) (resourceCalculatorPlugin.getPhysicalMemorySize() / 1024D / 1024);
View Full Code Here


  }

  @Override
  public Boolean isAlive() {
    long timeSinceHeartbeat = System.currentTimeMillis() - lastCMHeartbeat;
    CoronaConf cConf = new CoronaConf(fConf);
    long expire = cConf.getNodeExpiryInterval();
    if (timeSinceHeartbeat > expire) {
      return false;
    }
    return true;
  }
View Full Code Here

    String infoBindAddress = infoSocAddr.getHostName();
    int port = infoSocAddr.getPort();
    LOCALMACHINE = infoBindAddress;
    startTime = getClock().getTime();

    CoronaConf coronaConf = new CoronaConf(conf);
    InetSocketAddress rpcSockAddr = NetUtils.createSocketAddr(
      coronaConf.getProxyJobTrackerAddress());
    rpcServer = RPC.getServer(
      this,
      rpcSockAddr.getHostName(),
      rpcSockAddr.getPort(),
      conf.getInt("corona.proxy.job.tracker.handler.count", 10),
View Full Code Here

  }

  public static void main(String[] argv) throws IOException {

    StringUtils.startupShutdownMessage(ProxyJobTracker.class, argv, LOG);
    ProxyJobTracker p = startProxyTracker(new CoronaConf(new Configuration()));

    boolean joined = false;
    while (!joined) {
      try {
        p.join();
View Full Code Here

    String pool = null;
    if (sessionDriver != null) {
      pool = PoolInfo.createStringFromPoolInfo(sessionDriver.getPoolInfo());
    }
    try {
      CoronaConf coronaConf = new CoronaConf(conf);
      InetSocketAddress aggregatorAddr = NetUtils.createSocketAddr(
        coronaConf.getProxyJobTrackerAddress());
      long timeout = 5000; // Can make configurable later.
      CoronaJobAggregator aggregator = RPC.waitForProxy(
        CoronaJobAggregator.class,
        CoronaJobAggregator.versionID,
        aggregatorAddr,
View Full Code Here

  private volatile boolean isPurgingJob = true;
 
  private void initializePJTClient()
      throws IOException {
    InetSocketAddress address =
        NetUtils.createSocketAddr(new CoronaConf(conf).getProxyJobTrackerThriftAddress());
    pjtTransport = new TFramedTransport(
      new TSocket(address.getHostName(), address.getPort()));
    pjtClient =
      new CoronaProxyJobTrackerService.Client(new TBinaryProtocol(pjtTransport));
    try {
View Full Code Here

    Counters jobCounters = job.getCounters();
    JobStats jobStats = job.getJobStats();
    Counters errorCounters = job.getErrorCounters();
    String pool = getPoolInfo();
    try {
      CoronaConf coronaConf = new CoronaConf(conf);
      InetSocketAddress aggregatorAddr = NetUtils.createSocketAddr(
        coronaConf.getProxyJobTrackerAddress());
      long timeout = 5000; // Can make configurable later.
      ProtocolProxy<CoronaJobAggregator> aggregator = RPC.waitForProtocolProxy(
        CoronaJobAggregator.class,
        CoronaJobAggregator.versionID,
        aggregatorAddr,
View Full Code Here

    String infoBindAddress = infoSocAddr.getHostName();
    int port = infoSocAddr.getPort();
    LOCALMACHINE = infoBindAddress;
    startTime = getClock().getTime();

    CoronaConf coronaConf = new CoronaConf(conf);
    InetSocketAddress rpcSockAddr = NetUtils.createSocketAddr(
      coronaConf.getProxyJobTrackerAddress());
    rpcServer = RPC.getServer(
      this,
      rpcSockAddr.getHostName(),
      rpcSockAddr.getPort(),
      conf.getInt("corona.proxy.job.tracker.handler.count", 10),
View Full Code Here

  }

  public static void main(String[] argv) throws IOException {

    StringUtils.startupShutdownMessage(ProxyJobTracker.class, argv, LOG);
    ProxyJobTracker p = startProxyTracker(new CoronaConf(new Configuration()));

    boolean joined = false;
    while (!joined) {
      try {
        p.join();
View Full Code Here

  /**
   * Constructor.
   * @param conf The configuration.
   */
  public TrackerStats(Configuration conf) {
    CoronaConf coronaConf = new CoronaConf(conf);
    maxFailedConnections = coronaConf.getMaxFailedConnectionsPerSession();
    maxFailures = coronaConf.getMaxFailuresPerSession();
  }
View Full Code Here

TOP

Related Classes of org.apache.hadoop.corona.CoronaConf

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.