Java org.apache.hadoop.mapred JobClient fields, constructors, methods, implement or subclass

Example usage for Java org.apache.hadoop.mapred JobClient fields, constructors, methods, implement or subclass

Introduction

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

The text is from its open source code.

Subclass

org.apache.hadoop.mapred.JobClient has subclasses.
Click this link to see all its subclasses.

Constructor

JobClient(JobConf conf)
Build a job client with the given JobConf , and connect to the default cluster
JobClient(Configuration conf)
Build a job client with the given Configuration , and connect to the default cluster
JobClient()
Create a job client.
JobClient(InetSocketAddress jobTrackAddr, Configuration conf)
Build a job client, connect to the indicated job tracker.

Method

voidcancelDelegationToken(Token token)
Cancel a delegation token from the JobTracker
voidclose()
Close the JobClient.
JobStatus[]getAllJobs()
Get the jobs that are submitted.
TaskReport[]getCleanupTaskReports(JobID jobId)
Get the information of the current state of the cleanup tasks of a job.
ClusterStatusgetClusterStatus()
Get status information about the Map-Reduce cluster.
ClusterStatusgetClusterStatus(boolean detailed)
Get status information about the Map-Reduce cluster.
ConfigurationgetConf()
TokengetDelegationToken(final Text renewer)
Get a delegation token for the user from the JobTracker.
FileSystemgetFs()
Get a filesystem handle.
RunningJobgetJob(final JobID jobid)
Get an RunningJob object to track an ongoing job.
RunningJobgetJob(String jobid)
TaskReport[]getMapTaskReports(JobID jobId)
Get the information of the current state of the map tasks of a job.
TaskReport[]getMapTaskReports(String jobId)
QueueAclsInfo[]getQueueAclsForCurrentUser()
Gets the Queue ACLs for current user
JobQueueInfogetQueueInfo(final String queueName)
Gets the queue information associated to a particular Job Queue
JobQueueInfo[]getQueues()
Return an array of queue information objects about all the Job Queues configured.
TaskReport[]getReduceTaskReports(JobID jobId)
Get the information of the current state of the reduce tasks of a job.
TaskReport[]getReduceTaskReports(String jobId)
TaskReport[]getSetupTaskReports(JobID jobId)
Get the information of the current state of the setup tasks of a job.
PathgetSystemDir()
Grab the jobtracker system directory path where job-specific files are to be placed.
JobStatus[]jobsToComplete()
Get the jobs that are not completed and not failed.
booleanmonitorAndPrintJob(JobConf conf, RunningJob job)
Monitor a job and print status in real-time as progress is made and tasks fail.
RunningJobrunJob(JobConf job)
Utility that submits a job, then polls for progress until the job is complete.
voidsetConf(Configuration conf)
voidsetTaskOutputFilter(JobConf job, TaskStatusFilter newValue)
Modify the JobConf to set the task output filter.
RunningJobsubmitJob(String jobFile)
Submit a job to the MR system.
RunningJobsubmitJob(final JobConf conf)
Submit a job to the MR system.