Uses of Interface
org.apache.hadoop.mapreduce.Counter

Packages that use Counter
org.apache.hadoop.mapred   
org.apache.hadoop.mapreduce   
org.apache.hadoop.mapreduce.counters This package contains the implementations of different types of map-reduce counters. 
org.apache.hadoop.mapreduce.lib.map   
org.apache.hadoop.mapreduce.lib.reduce   
org.apache.hadoop.mapreduce.task   
org.apache.hadoop.mapreduce.util   
 

Uses of Counter in org.apache.hadoop.mapred
 

Classes in org.apache.hadoop.mapred that implement Counter
static class Counters.Counter
          A counter record, comprising its name and value.
 

Methods in org.apache.hadoop.mapred that return Counter
 Counter TaskAttemptContextImpl.getCounter(Enum<?> counterName)
           
 Counter TaskAttemptContextImpl.getCounter(String groupName, String counterName)
           
 Counter Counters.Counter.getUnderlyingCounter()
           
 

Methods in org.apache.hadoop.mapred with parameters of type Counter
protected static
<INKEY,INVALUE,OUTKEY,OUTVALUE>
Reducer.Context
Task.createReduceContext(Reducer<INKEY,INVALUE,OUTKEY,OUTVALUE> reducer, org.apache.hadoop.conf.Configuration job, TaskAttemptID taskId, RawKeyValueIterator rIter, Counter inputKeyCounter, Counter inputValueCounter, RecordWriter<OUTKEY,OUTVALUE> output, OutputCommitter committer, StatusReporter reporter, org.apache.hadoop.io.RawComparator<INKEY> comparator, Class<INKEY> keyClass, Class<INVALUE> valueClass)
           
 

Uses of Counter in org.apache.hadoop.mapreduce
 

Methods in org.apache.hadoop.mapreduce that return Counter
abstract  Counter StatusReporter.getCounter(Enum<?> name)
           
 Counter TaskAttemptContext.getCounter(Enum<?> counterName)
          Get the Counter for the given counterName.
abstract  Counter StatusReporter.getCounter(String group, String name)
           
 Counter TaskAttemptContext.getCounter(String groupName, String counterName)
          Get the Counter for the given groupName and counterName.
 Counter Counter.getUnderlyingCounter()
           
 

Uses of Counter in org.apache.hadoop.mapreduce.counters
 

Classes in org.apache.hadoop.mapreduce.counters with type parameters of type Counter
 class AbstractCounterGroup<T extends Counter>
          An abstract class to provide common implementation of the generic counter group in both mapred and mapreduce package.
 class AbstractCounters<C extends Counter,G extends CounterGroupBase<C>>
          An abstract class to provide common implementation for the Counters container in both mapred and mapreduce packages.
 interface CounterGroupBase<T extends Counter>
          The common counter group interface.
 class CounterGroupFactory<C extends Counter,G extends CounterGroupBase<C>>
          An abstract class to provide common implementation of the group factory in both mapred and mapreduce packages.
 class FileSystemCounterGroup<C extends Counter>
          An abstract class to provide common implementation of the filesystem counter group in both mapred and mapreduce packages.
 class FrameworkCounterGroup<T extends Enum<T>,C extends Counter>
          An abstract class to provide common implementation for the framework counter group in both mapred and mapreduce packages.
 

Classes in org.apache.hadoop.mapreduce.counters that implement Counter
 class AbstractCounter
          An abstract counter class to provide common implementation of the counter interface in both mapred and mapreduce packages.
static class FileSystemCounterGroup.FSCounter
           
static class FrameworkCounterGroup.FrameworkCounter<T extends Enum<T>>
          A counter facade for framework counters.
 class GenericCounter
          A generic counter implementation
 

Methods in org.apache.hadoop.mapreduce.counters that return Counter
 Counter GenericCounter.getUnderlyingCounter()
           
 Counter FileSystemCounterGroup.FSCounter.getUnderlyingCounter()
           
 Counter FrameworkCounterGroup.FrameworkCounter.getUnderlyingCounter()
           
 

Uses of Counter in org.apache.hadoop.mapreduce.lib.map
 

Methods in org.apache.hadoop.mapreduce.lib.map that return Counter
 Counter WrappedMapper.Context.getCounter(Enum<?> counterName)
           
 Counter WrappedMapper.Context.getCounter(String groupName, String counterName)
           
 

Uses of Counter in org.apache.hadoop.mapreduce.lib.reduce
 

Methods in org.apache.hadoop.mapreduce.lib.reduce that return Counter
 Counter WrappedReducer.Context.getCounter(Enum counterName)
           
 Counter WrappedReducer.Context.getCounter(String groupName, String counterName)
           
 

Uses of Counter in org.apache.hadoop.mapreduce.task
 

Methods in org.apache.hadoop.mapreduce.task that return Counter
 Counter TaskAttemptContextImpl.getCounter(Enum<?> counterName)
           
 Counter TaskAttemptContextImpl.DummyReporter.getCounter(Enum<?> name)
           
 Counter TaskAttemptContextImpl.getCounter(String groupName, String counterName)
           
 Counter TaskAttemptContextImpl.DummyReporter.getCounter(String group, String name)
           
 

Constructors in org.apache.hadoop.mapreduce.task with parameters of type Counter
ReduceContextImpl(org.apache.hadoop.conf.Configuration conf, TaskAttemptID taskid, RawKeyValueIterator input, Counter inputKeyCounter, Counter inputValueCounter, RecordWriter<KEYOUT,VALUEOUT> output, OutputCommitter committer, StatusReporter reporter, org.apache.hadoop.io.RawComparator<KEYIN> comparator, Class<KEYIN> keyClass, Class<VALUEIN> valueClass)
           
 

Uses of Counter in org.apache.hadoop.mapreduce.util
 

Methods in org.apache.hadoop.mapreduce.util with type parameters of type Counter
static
<C extends Counter,G extends CounterGroupBase<C>,T extends AbstractCounters<C,G>>
T
CountersStrings.parseEscapedCompactString(String compactString, T counters)
          Parse a pre 0.21 counters string into a counter object.
static
<C extends Counter,G extends CounterGroupBase<C>,T extends AbstractCounters<C,G>>
String
CountersStrings.toEscapedCompactString(T counters)
          Make the pre 0.21 counters string
 

Methods in org.apache.hadoop.mapreduce.util with parameters of type Counter
static String CountersStrings.toEscapedCompactString(Counter counter)
          Make the pre 0.21 counter string (for e.g.
 



Copyright © 2014 Apache Software Foundation. All Rights Reserved.