Uses of Class
org.apache.hadoop.mapred.TaskTrackerStatus

Packages that use TaskTrackerStatus
org.apache.hadoop.mapred A software framework for easily writing applications which process vast amounts of data (multi-terabyte data-sets) parallelly on large clusters (thousands of nodes) built of commodity hardware in a reliable, fault-tolerant manner. 
org.apache.hadoop.mapreduce.server.jobtracker   
 

Uses of TaskTrackerStatus in org.apache.hadoop.mapred
 

Methods in org.apache.hadoop.mapred that return TaskTrackerStatus
 TaskTrackerStatus JobTracker.getTaskTrackerStatus(String trackerID)
           
 

Methods in org.apache.hadoop.mapred that return types with arguments of type TaskTrackerStatus
 Collection<TaskTrackerStatus> JobTracker.activeTaskTrackers()
          Get the active task tracker statuses in the cluster
 Collection<TaskTrackerStatus> JobTracker.blacklistedTaskTrackers()
          Get the statuses of the blacklisted task trackers in the cluster.
 Collection<TaskTrackerStatus> JobTracker.graylistedTaskTrackers()
          Get the statuses of the graylisted task trackers in the cluster.
 Collection<TaskTrackerStatus> JobTracker.taskTrackers()
          Get all the task trackers in the cluster
 

Methods in org.apache.hadoop.mapred with parameters of type TaskTrackerStatus
protected  org.apache.hadoop.mapred.TaskInProgress JobInProgress.findSpeculativeTask(Collection<org.apache.hadoop.mapred.TaskInProgress> list, TaskTrackerStatus ttStatus, double avgProgress, long currentTime, boolean shouldRemove)
          Find a speculative task
 org.apache.hadoop.mapred.HeartbeatResponse JobTracker.heartbeat(TaskTrackerStatus status, boolean restarted, boolean initialContact, boolean acceptNewTasks, short responseId)
          The periodic heartbeat mechanism between the TaskTracker and the JobTracker.
 Task JobInProgress.obtainJobCleanupTask(TaskTrackerStatus tts, int clusterSize, int numUniqueHosts, boolean isMapSlot)
          Return a CleanupTask, if appropriate, to run on the given tasktracker
 Task JobInProgress.obtainJobSetupTask(TaskTrackerStatus tts, int clusterSize, int numUniqueHosts, boolean isMapSlot)
          Return a SetupTask, if appropriate, to run on the given tasktracker
 Task JobInProgress.obtainNewMapTask(TaskTrackerStatus tts, int clusterSize, int numUniqueHosts)
          Return a MapTask, if appropriate, to run on the given tasktracker
 Task JobInProgress.obtainNewNodeLocalMapTask(TaskTrackerStatus tts, int clusterSize, int numUniqueHosts)
           
 Task JobInProgress.obtainNewNodeOrRackLocalMapTask(TaskTrackerStatus tts, int clusterSize, int numUniqueHosts)
           
 Task JobInProgress.obtainNewNonLocalMapTask(TaskTrackerStatus tts, int clusterSize, int numUniqueHosts)
           
 Task JobInProgress.obtainNewReduceTask(TaskTrackerStatus tts, int clusterSize, int numUniqueHosts)
          Return a ReduceTask, if appropriate, to run on the given tasktracker.
 Task JobInProgress.obtainTaskCleanupTask(TaskTrackerStatus tts, boolean isMapSlot)
           
 

Uses of TaskTrackerStatus in org.apache.hadoop.mapreduce.server.jobtracker
 

Methods in org.apache.hadoop.mapreduce.server.jobtracker that return TaskTrackerStatus
 TaskTrackerStatus TaskTracker.getStatus()
          Get the current TaskTrackerStatus of the TaskTracker.
 

Methods in org.apache.hadoop.mapreduce.server.jobtracker with parameters of type TaskTrackerStatus
 void TaskTracker.setStatus(TaskTrackerStatus status)
          Set the current TaskTrackerStatus of the TaskTracker.
 



Copyright © 2009 The Apache Software Foundation