Package org.apache.hadoop.corona

Examples of org.apache.hadoop.corona.InetAddress


    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


  @SuppressWarnings("deprecation")
  public void killJob(JobID jobId, Map<String, InetAddress> allTrackers) {
    int workerId = 0;
    for (Map.Entry<String, InetAddress> entry : allTrackers.entrySet()) {
      String trackerName = entry.getKey();
      InetAddress addr = entry.getValue();
      String description = "KillJobAction " + jobId;
      ActionToSend action = new ActionToSend(trackerName, addr,
          new KillJobAction(jobId), description);
      workers[workerId].enqueueAction(action);
      LOG.info("Queueing "  + description + " to worker " + workerId + " " +
View Full Code Here

  }

  private void updateTrackerAddressUnprotected(ResourceGrant grant) {
    String trackerName = grant.getNodeName();
    // Update address information for trackers.
    InetAddress addr = Utilities.appInfoToAddress(grant.appInfo);
    trackerAddress.put(trackerName, addr);
  }
View Full Code Here

      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);
    Task task = getSetupAndCleanupTasks(trackerName, addr.host, isMapGrant);
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

              continue;
            }
            if (tip.shouldCommit(taskId)) {
              Integer grant = taskLookupTable.getGrantIdForTask(taskId);
              if (grant != null) {
                InetAddress addr = Utilities.appInfoToAddress(
                    resourceTracker.getGrant(grant).getAppInfo());
                CommitTaskAction commitAction = new CommitTaskAction(taskId);
                saveList.add(commitAction);
                LOG.debug(tts.getTrackerName() +
                    " -> CommitTaskAction: " + taskId);
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

   */
  @SuppressWarnings("deprecation")
  public void killJob(JobID jobId, Map<String, InetAddress> allTrackers) {
    for (Map.Entry<String, InetAddress> entry : allTrackers.entrySet()) {
      String trackerName = entry.getKey();
      InetAddress addr = entry.getValue();
      String description = "KillJobAction " + jobId;
      ActionToSend action = new ActionToSend(trackerName, addr,
          new KillJobAction(jobId), description);
      allWorkQueues.enqueueAction(action);
      LOG.info("Queueing "  + description + " to worker " +
View Full Code Here

  }

  private void updateTrackerAddressUnprotected(ResourceGrant grant) {
    String trackerName = grant.getNodeName();
    // Update address information for trackers.
    InetAddress addr = Utilities.appInfoToAddress(grant.appInfo);
    trackerAddress.put(trackerName, addr);
  }
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.