org.apache.hadoop.mapred
Class OutputCommitter

java.lang.Object
  extended by org.apache.hadoop.mapreduce.OutputCommitter
      extended by org.apache.hadoop.mapred.OutputCommitter
Direct Known Subclasses:
FileOutputCommitter

Deprecated. Use OutputCommitter instead.

@Deprecated
public abstract class OutputCommitter
extends OutputCommitter

OutputCommitter describes the commit of task output for a Map-Reduce job.

The Map-Reduce framework relies on the OutputCommitter of the job to:

  1. Setup the job during initialization. For example, create the temporary output directory for the job during the initialization of the job.
  2. Cleanup the job after the job completion. For example, remove the temporary output directory after the job completion.
  3. Setup the task temporary output.
  4. Check whether a task needs a commit. This is to avoid the commit procedure if a task does not need commit.
  5. Commit of the task output.
  6. Discard the task commit.

See Also:
FileOutputCommitter, JobContext, TaskAttemptContext

Constructor Summary
OutputCommitter()
          Deprecated.  
 
Method Summary
abstract  void abortTask(TaskAttemptContext taskContext)
          Deprecated. Discard the task output
 void abortTask(TaskAttemptContext taskContext)
          Deprecated. This method implements the new interface by calling the old method.
abstract  void cleanupJob(JobContext jobContext)
          Deprecated. For cleaning up the job's output after job completion
 void cleanupJob(JobContext context)
          Deprecated. This method implements the new interface by calling the old method.
abstract  void commitTask(TaskAttemptContext taskContext)
          Deprecated. To promote the task's temporary output to final output location The task's output is moved to the job's output directory.
 void commitTask(TaskAttemptContext taskContext)
          Deprecated. This method implements the new interface by calling the old method.
abstract  boolean needsTaskCommit(TaskAttemptContext taskContext)
          Deprecated. Check whether task needs a commit
 boolean needsTaskCommit(TaskAttemptContext taskContext)
          Deprecated. This method implements the new interface by calling the old method.
abstract  void setupJob(JobContext jobContext)
          Deprecated. For the framework to setup the job output during initialization
 void setupJob(JobContext jobContext)
          Deprecated. This method implements the new interface by calling the old method.
abstract  void setupTask(TaskAttemptContext taskContext)
          Deprecated. Sets up output for the task.
 void setupTask(TaskAttemptContext taskContext)
          Deprecated. This method implements the new interface by calling the old method.
 
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
 

Constructor Detail

OutputCommitter

public OutputCommitter()
Deprecated. 
Method Detail

setupJob

public abstract void setupJob(JobContext jobContext)
                       throws IOException
Deprecated. 
For the framework to setup the job output during initialization

Parameters:
jobContext - Context of the job whose output is being written.
Throws:
IOException - if temporary output could not be created

cleanupJob

public abstract void cleanupJob(JobContext jobContext)
                         throws IOException
Deprecated. 
For cleaning up the job's output after job completion

Parameters:
jobContext - Context of the job whose output is being written.
Throws:
IOException

setupTask

public abstract void setupTask(TaskAttemptContext taskContext)
                        throws IOException
Deprecated. 
Sets up output for the task.

Parameters:
taskContext - Context of the task whose output is being written.
Throws:
IOException

needsTaskCommit

public abstract boolean needsTaskCommit(TaskAttemptContext taskContext)
                                 throws IOException
Deprecated. 
Check whether task needs a commit

Parameters:
taskContext -
Returns:
true/false
Throws:
IOException

commitTask

public abstract void commitTask(TaskAttemptContext taskContext)
                         throws IOException
Deprecated. 
To promote the task's temporary output to final output location The task's output is moved to the job's output directory.

Parameters:
taskContext - Context of the task whose output is being written.
Throws:
IOException - if commit is not

abortTask

public abstract void abortTask(TaskAttemptContext taskContext)
                        throws IOException
Deprecated. 
Discard the task output

Parameters:
taskContext -
Throws:
IOException

setupJob

public final void setupJob(JobContext jobContext)
                    throws IOException
Deprecated. 
This method implements the new interface by calling the old method. Note that the input types are different between the new and old apis and this is a bridge between the two.

Specified by:
setupJob in class OutputCommitter
Parameters:
jobContext - Context of the job whose output is being written.
Throws:
IOException - if temporary output could not be created

cleanupJob

public final void cleanupJob(JobContext context)
                      throws IOException
Deprecated. 
This method implements the new interface by calling the old method. Note that the input types are different between the new and old apis and this is a bridge between the two.

Specified by:
cleanupJob in class OutputCommitter
Parameters:
context - Context of the job whose output is being written.
Throws:
IOException

setupTask

public final void setupTask(TaskAttemptContext taskContext)
                     throws IOException
Deprecated. 
This method implements the new interface by calling the old method. Note that the input types are different between the new and old apis and this is a bridge between the two.

Specified by:
setupTask in class OutputCommitter
Parameters:
taskContext - Context of the task whose output is being written.
Throws:
IOException

needsTaskCommit

public final boolean needsTaskCommit(TaskAttemptContext taskContext)
                              throws IOException
Deprecated. 
This method implements the new interface by calling the old method. Note that the input types are different between the new and old apis and this is a bridge between the two.

Specified by:
needsTaskCommit in class OutputCommitter
Returns:
true/false
Throws:
IOException

commitTask

public final void commitTask(TaskAttemptContext taskContext)
                      throws IOException
Deprecated. 
This method implements the new interface by calling the old method. Note that the input types are different between the new and old apis and this is a bridge between the two.

Specified by:
commitTask in class OutputCommitter
Parameters:
taskContext - Context of the task whose output is being written.
Throws:
IOException - if commit is not

abortTask

public final void abortTask(TaskAttemptContext taskContext)
                     throws IOException
Deprecated. 
This method implements the new interface by calling the old method. Note that the input types are different between the new and old apis and this is a bridge between the two.

Specified by:
abortTask in class OutputCommitter
Throws:
IOException


Copyright © 2009 The Apache Software Foundation