Package org.apache.hadoop.corona

Examples of org.apache.hadoop.corona.InetAddress


      LOG.info("Resource " + grant.getId() + " nodename " +
        grant.getNodeName() + " is not needed");
      processBadResource(grant.getId(), false);
      return true;
    }
    InetAddress addr =
      Utilities.appInfoToAddress(grant.appInfo);
    String trackerName = grant.getNodeName();
    boolean isMapGrant =
        grant.getType().equals(ResourceType.MAP);
    // This process has to be replayed during restarting job
View Full Code Here


    }
    return false;
  }

  public boolean isBadResource(ResourceGrant grant) {
    InetAddress addr = grant.address;
    String trackerName = grant.getNodeName();
    TaskInProgress tip = requestToTipMap.get(grant.getId());
    return trackerStats.isFaulty(trackerName) ||
           !job.canTrackerBeUsed(trackerName, addr.host, tip) ||
           job.isBadSpeculativeResource(tip, trackerName, addr.host);
View Full Code Here

           !job.canTrackerBeUsed(trackerName, addr.host, tip) ||
           job.isBadSpeculativeResource(tip, trackerName, addr.host);
  }

  public boolean isResourceNeeded(ResourceGrant grant) {
    InetAddress addr = grant.address;
    String trackerName = grant.getNodeName();
    TaskInProgress tip = requestToTipMap.get(grant.getId());
    // 1. If the task is running and we can speculate
    // 2. If the task is not running, but is runnable
    // 3. If we are about to reuse a tip for something else
View Full Code Here

    TaskAttemptID attemptId = launch.getTaskId();
    TaskInProgress tip = job.getTaskInProgress(attemptId.getTaskID());
    String trackerName = launch.getTrackerName();
    InetSocketAddress trackerAddr = launch.getAddress();
    // Update trackerName -> trackerAddress mapping in ResourceTracker
    resourceTracker.updateTrackerAddr(trackerName, new InetAddress(
        trackerAddr.getHostName(), trackerAddr.getPort()));
    Task task = null;
    if (tip.isMapTask()) {
      task = job.forceNewMapTaskForTip(trackerName,
          trackerAddr.getHostName(), tip);
View Full Code Here

  }

  private void queueKillActions(String trackerName) {
    List<KillTaskAction> killActions =
        taskLookupTable.getTasksToKill(trackerName);
    InetAddress addr =
        resourceTracker.getTrackerAddr(trackerName);
    taskLauncher.killTasks(trackerName, addr, killActions);
  }
View Full Code Here

    args.protocolFactory(protocolFactory);
    clusterManagerCallbackServer = new TThreadPoolServer(args);
    clusterManagerCallbackServerThread =
        new TServerThread(clusterManagerCallbackServer);
    clusterManagerCallbackServerThread.start();
    clusterManagerCallbackServerAddr = new InetAddress(
        getLocalHostname(), serverSocket.getLocalPort());
    LOG.info("SessionServer up at " + serverSocket.getLocalSocketAddress());
  }
View Full Code Here

TOP

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

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.