Java org.apache.hadoop.mapreduce Job fields, constructors, methods, implement or subclass

Example usage for Java org.apache.hadoop.mapreduce Job fields, constructors, methods, implement or subclass

Introduction

In this page you can find the methods, fields and constructors for org.apache.hadoop.mapreduce Job.

The text is from its open source code.

Subclass

org.apache.hadoop.mapreduce.Job has subclasses.
Click this link to see all its subclasses.

Field

Constructor

Method

voidaddArchiveToClassPath(Path archive)
Add an archive path to the current set of classpath entries.
voidaddCacheArchive(URI uri)
Add a archives to be localized
voidaddCacheFile(URI uri)
Add a file to be localized
voidaddFileToClassPath(Path file)
Add an file path to the current set of classpath entries It adds the file to cache as well.
voidcreateSymlink()
Originally intended to enable symlinks, but currently symlinks cannot be disabled.
URI[]getCacheArchives()
Get cache archives set in the Configuration
URI[]getCacheFiles()
Get cache files set in the Configuration
ClustergetCluster()
Class>getCombinerClass()
Get the combiner class for the job.
ConfigurationgetConfiguration()
Return the configuration for the job.
CountersgetCounters()
Gets the counters for this job.
CredentialsgetCredentials()
longgetFinishTime()
Get finish time of the job.
RawComparatorgetGroupingComparator()
Get the user defined RawComparator comparator for grouping keys of inputs to the reduce.
Class>getInputFormatClass()
Get the InputFormat class for the job.
JobgetInstance(Configuration conf, String jobName)
Creates a new Job with no particular Cluster and a given jobName.
JobgetInstance(JobStatus status, Configuration conf)
Creates a new Job with no particular Cluster and given Configuration and JobStatus .
JobgetInstance(Cluster ignored, Configuration conf)
Creates a new Job with no particular Cluster and given Configuration .
JobgetInstance(Configuration conf)
Creates a new Job with no particular Cluster and a given Configuration .
JobgetInstance(Cluster ignored)
Creates a new Job with no particular Cluster .
JobgetInstance()
Creates a new Job with no particular Cluster .
StringgetJar()
Get the pathname of the job's jar.
StringgetJobFile()
Get the path of the submitted job configuration.
JobIDgetJobID()
Get the unique ID for the job.
StringgetJobName()
The user-specified job name.
JobStatus.StategetJobState()
Returns the current state of the Job.
ClassgetMapOutputKeyClass()
Get the key class for the map output data.
ClassgetMapOutputValueClass()
Get the value class for the map output data.
Class>getMapperClass()
Get the Mapper class for the job.
intgetNumReduceTasks()
Get configured the number of reduce tasks for this job.
Class>getOutputFormatClass()
Get the OutputFormat class for the job.
ClassgetOutputKeyClass()
Get the key class for the job output data.
ClassgetOutputValueClass()
Get the value class for job outputs.
Class>getPartitionerClass()
Get the Partitioner class for the job.
Class>getReducerClass()
Get the Reducer class for the job.
RawComparatorgetSortComparator()
Get the RawComparator comparator used to compare keys.
longgetStartTime()
Get start time of the job.
JobStatusgetStatus()
org.apache.hadoop.mapred.TaskCompletionEvent[]getTaskCompletionEvents(final int startFrom)
Get events indicating completion (success/failure) of component tasks.
TaskCompletionEvent[]getTaskCompletionEvents(final int startFrom, final int numEvents)
Get events indicating completion (success/failure) of component tasks.
String[]getTaskDiagnostics(final TaskAttemptID taskid)
Gets the diagnostic messages for a given task attempt.
TaskReport[]getTaskReports(TaskType type)
Get the information of the current state of the tasks of a job.
StringgetTrackingURL()
Get the URL where some job progress information will be displayed.
PathgetWorkingDirectory()
Get the current working directory for the default file system.
booleanisComplete()
Check if the job is finished or not.
booleanisRetired()
booleanisSuccessful()
Check if the job completed successfully.
voidkillJob()
Kill the running job.
floatmapProgress()
Get the progress of the job's map-tasks, as a float between 0.0 and 1.0.
booleanmonitorAndPrintJob()
Monitor a job and print status in real-time as progress is made and tasks fail.
floatreduceProgress()
Get the progress of the job's reduce-tasks, as a float between 0.0 and 1.0.
voidsetCombinerClass(Class cls)
Set the combiner class for the job.
voidsetCombinerKeyGroupingComparatorClass(Class cls)
Define the comparator that controls which keys are grouped together for a single call to combiner, Reducer#reduce(Object,Iterable,org.apache.hadoop.mapreduce.Reducer.Context)
voidsetGroupingComparatorClass(Class cls)
Define the comparator that controls which keys are grouped together for a single call to Reducer#reduce(Object,Iterable,org.apache.hadoop.mapreduce.Reducer.Context)
voidsetInputFormatClass(Class cls)
Set the InputFormat for the job.
voidsetJar(String jar)
Set the job jar
voidsetJarByClass(Class cls)
Set the Jar by finding where a given class came from.
voidsetJobID(JobID jobId)
Set the JobID.
voidsetJobName(String name)
Set the user-specified job name.
voidsetMapOutputKeyClass(Class theClass)
Set the key class for the map output data.
voidsetMapOutputValueClass(Class theClass)
Set the value class for the map output data.
voidsetMapperClass(Class cls)
Set the Mapper for the job.
voidsetMapSpeculativeExecution(boolean speculativeExecution)
Turn speculative execution on or off for this job for map tasks.
voidsetMaxMapAttempts(int n)
Expert: Set the number of maximum attempts that will be made to run a map task.
voidsetMaxReduceAttempts(int n)
Expert: Set the number of maximum attempts that will be made to run a reduce task.
voidsetNumReduceTasks(int tasks)
Set the number of reduce tasks for the job.
voidsetOutputFormatClass(Class cls)
Set the OutputFormat for the job.
voidsetOutputKeyClass(Class theClass)
Set the key class for the job output data.
voidsetOutputValueClass(Class theClass)
Set the value class for job outputs.
voidsetPartitionerClass(Class cls)
Set the Partitioner for the job.
voidsetReducerClass(Class cls)
Set the Reducer for the job.
voidsetReduceSpeculativeExecution(boolean speculativeExecution)
Turn speculative execution on or off for this job for reduce tasks.
voidsetSortComparatorClass(Class cls)
Define the comparator that controls how the keys are sorted before they are passed to the Reducer .
voidsetSpeculativeExecution(boolean speculativeExecution)
Turn speculative execution on or off for this job.
floatsetupProgress()
Get the progress of the job's setup-tasks, as a float between 0.0 and 1.0.
voidsetWorkingDirectory(Path dir)
Set the current working directory for the default file system.
voidsubmit()
Submit the job to the cluster and return immediately.
StringtoString()
Dump stats to screen.
booleanwaitForCompletion(boolean verbose)
Submit the job to the cluster and wait for it to finish.