Uses of Class
org.apache.hadoop.mapreduce.Counters

Packages that use Counters
org.apache.hadoop.mapred   
org.apache.hadoop.mapreduce   
org.apache.hadoop.mapreduce.jobhistory   
org.apache.hadoop.mapreduce.protocol   
org.apache.hadoop.mapreduce.tools   
 

Uses of Counters in org.apache.hadoop.mapred
 

Methods in org.apache.hadoop.mapred with parameters of type Counters
protected  long JobClient.getCounter(Counters cntrs, String counterGroupName, String counterName)
           
 

Constructors in org.apache.hadoop.mapred with parameters of type Counters
Counters(Counters newCounters)
           
 

Uses of Counters in org.apache.hadoop.mapreduce
 

Methods in org.apache.hadoop.mapreduce that return Counters
 Counters Job.getCounters()
          Gets the counters for this job.
 Counters TaskReport.getTaskCounters()
          A table of counters.
 

Constructors in org.apache.hadoop.mapreduce with parameters of type Counters
TaskReport(TaskID taskid, float progress, String state, String[] diagnostics, TIPStatus currentStatus, long startTime, long finishTime, Counters counters)
          Creates a new TaskReport object
 

Uses of Counters in org.apache.hadoop.mapreduce.jobhistory
 

Methods in org.apache.hadoop.mapreduce.jobhistory that return Counters
 Counters JobHistoryParser.TaskInfo.getCounters()
           
 Counters JobHistoryParser.TaskAttemptInfo.getCounters()
           
 Counters TaskFailedEvent.getCounters()
          Get task counters
 Counters TaskFinishedEvent.getCounters()
          Get task counters
 Counters JobFinishedEvent.getMapCounters()
          Get the Map counters for the job
 Counters JobHistoryParser.JobInfo.getMapCounters()
           
 Counters JobFinishedEvent.getReduceCounters()
          Get the reduce counters for the job
 Counters JobHistoryParser.JobInfo.getReduceCounters()
           
 Counters JobFinishedEvent.getTotalCounters()
          Get the counters for the job
 Counters JobHistoryParser.JobInfo.getTotalCounters()
           
 

Constructors in org.apache.hadoop.mapreduce.jobhistory with parameters of type Counters
JobFinishedEvent(JobID id, long finishTime, int finishedMaps, int finishedReduces, int failedMaps, int failedReduces, Counters mapCounters, Counters reduceCounters, Counters totalCounters)
          Create an event to record successful job completion
MapAttemptFinishedEvent(TaskAttemptID id, TaskType taskType, String taskStatus, long mapFinishTime, long finishTime, String hostname, int port, String rackName, String state, Counters counters, int[][] allSplits)
          Create an event for successful completion of map attempts
MapAttemptFinishedEvent(TaskAttemptID id, TaskType taskType, String taskStatus, long mapFinishTime, long finishTime, String hostname, String state, Counters counters)
          Deprecated. please use the constructor with an additional argument, an array of splits arrays instead. See ProgressSplitsBlock for an explanation of the meaning of that parameter. Create an event for successful completion of map attempts
ReduceAttemptFinishedEvent(TaskAttemptID id, TaskType taskType, String taskStatus, long shuffleFinishTime, long sortFinishTime, long finishTime, String hostname, int port, String rackName, String state, Counters counters, int[][] allSplits)
          Create an event to record completion of a reduce attempt
ReduceAttemptFinishedEvent(TaskAttemptID id, TaskType taskType, String taskStatus, long shuffleFinishTime, long sortFinishTime, long finishTime, String hostname, String state, Counters counters)
          Deprecated. please use the constructor with an additional argument, an array of splits arrays instead. See ProgressSplitsBlock for an explanation of the meaning of that parameter. Create an event to record completion of a reduce attempt
TaskAttemptFinishedEvent(TaskAttemptID id, TaskType taskType, String taskStatus, long finishTime, String rackName, String hostname, String state, Counters counters)
          Create an event to record successful finishes for setup and cleanup attempts
TaskAttemptUnsuccessfulCompletionEvent(TaskAttemptID id, TaskType taskType, String status, long finishTime, String hostname, int port, String rackName, String error, Counters counters, int[][] allSplits)
          Create an event to record the unsuccessful completion of attempts
TaskFailedEvent(TaskID id, long finishTime, TaskType taskType, String error, String status, TaskAttemptID failedDueToAttempt, Counters counters)
          Create an event to record task failure
TaskFinishedEvent(TaskID id, TaskAttemptID attemptId, long finishTime, TaskType taskType, String status, Counters counters)
          Create an event to record the successful completion of a task
 

Uses of Counters in org.apache.hadoop.mapreduce.protocol
 

Methods in org.apache.hadoop.mapreduce.protocol that return Counters
 Counters ClientProtocol.getJobCounters(JobID jobid)
          Grab the current job counters
 

Uses of Counters in org.apache.hadoop.mapreduce.tools
 

Methods in org.apache.hadoop.mapreduce.tools with parameters of type Counters
protected  long CLI.getCounter(Counters counters, String counterGroupName, String counterName)
           
 



Copyright © 2013 Apache Software Foundation. All Rights Reserved.