public interface JTProtocols extends RefreshUserMappingsProtocol, GetUserMappingsProtocol, RefreshAuthorizationPolicyProtocol, AdminOperationsProtocol
Modifier and Type | Field and Description |
---|---|
static int |
TRACKERS_OK |
static int |
UNKNOWN_TASKTRACKER |
static long |
versionID
version 3 introduced to replace
emitHearbeat/pollForNewTask/pollForTaskWithClosedJob with
heartbeat(TaskTrackerStatus, boolean, boolean, boolean, short)
version 4 changed TaskReport for HADOOP-549. |
static long |
versionID |
versionID
versionID
versionID
versionID
Modifier and Type | Method and Description |
---|---|
void |
addJobInProgressListener(org.apache.hadoop.mapred.JobInProgressListener listener)
Registers a
JobInProgressListener for updates from this
TaskTrackerManager . |
void |
cancelDelegationToken(org.apache.hadoop.security.token.Token<DelegationTokenIdentifier> token)
Cancel a delegation token.
|
void |
failJob(JobInProgress job)
Fail a job.
|
JobStatus[] |
getAllJobs()
Get all the jobs submitted.
|
java.lang.String |
getBuildVersion()
Returns the VersionInfo build version of the JobTracker
|
TaskReport[] |
getCleanupTaskReports(JobID jobid)
Grab a bunch of info on the cleanup tasks that make up the job
|
ClusterStatus |
getClusterStatus() |
ClusterStatus |
getClusterStatus(boolean detailed)
Get the current status of the cluster
|
org.apache.hadoop.security.token.Token<DelegationTokenIdentifier> |
getDelegationToken(org.apache.hadoop.io.Text renewer)
Get a new delegation token.
|
java.lang.String |
getFilesystemName()
The task tracker calls this once, to discern where it can find
files referred to by the JobTracker
|
java.lang.String |
getFilesystemName()
A MapReduce system always operates on a single filesystem.
|
JobInProgress |
getJob(JobID jobid)
Obtain the job object identified by jobid
|
Counters |
getJobCounters(JobID jobid)
Grab the current job counters
|
JobProfile |
getJobProfile(JobID jobid)
Grab a handle to a job that is already known to the JobTracker.
|
JobStatus[] |
getJobsFromQueue(java.lang.String queue)
Gets all the jobs submitted to the particular Queue
|
JobStatus |
getJobStatus(JobID jobid)
Grab a handle to a job that is already known to the JobTracker.
|
TaskReport[] |
getMapTaskReports(JobID jobid)
Grab a bunch of info on the map tasks that make up the job
|
JobID |
getNewJobId()
Allocate a name for the job.
|
int |
getNextHeartbeatInterval()
Return the current heartbeat interval that's used by
TaskTracker s. |
int |
getNumberOfUniqueHosts() |
org.apache.hadoop.mapred.QueueAclsInfo[] |
getQueueAclsForCurrentUser()
Gets the Queue ACLs for current user
|
org.apache.hadoop.security.authorize.AccessControlList |
getQueueAdmins(java.lang.String queueName)
Get the administrators of the given job-queue.
|
JobQueueInfo |
getQueueInfo(java.lang.String queue)
Gets scheduling information associated with the particular Job queue
|
org.apache.hadoop.mapred.QueueManager |
getQueueManager()
Return the
QueueManager which manages the queues in this
TaskTrackerManager . |
JobQueueInfo[] |
getQueues()
Gets set of Job Queues associated with the Job Tracker
|
TaskReport[] |
getReduceTaskReports(JobID jobid)
Grab a bunch of info on the reduce tasks that make up the job
|
TaskReport[] |
getSetupTaskReports(JobID jobid)
Grab a bunch of info on the setup tasks that make up the job
|
java.lang.String |
getStagingAreaDir()
Get a hint from the JobTracker
where job-specific files are to be placed.
|
java.lang.String |
getSystemDir()
Grab the jobtracker system directory path where job-specific files are to be placed.
|
java.lang.String |
getSystemDir()
Grab the jobtracker system directory path where job-specific files are to be placed.
|
TaskCompletionEvent[] |
getTaskCompletionEvents(JobID jobid,
int fromEventId,
int maxEvents)
Get task completion events for the jobid, starting from fromEventId.
|
TaskCompletionEvent[] |
getTaskCompletionEvents(JobID jobid,
int fromEventId,
int maxEvents)
Get task completion events for the jobid, starting from fromEventId.
|
java.lang.String[] |
getTaskDiagnostics(TaskAttemptID taskId)
Get the diagnostics for a given task in a given job
|
java.lang.String |
getVIVersion()
Returns the VersionInfo version of the JobTracker
|
org.apache.hadoop.mapred.HeartbeatResponse |
heartbeat(TaskTrackerStatus status,
boolean restarted,
boolean initialContact,
boolean acceptNewTasks,
short responseId)
Called regularly by the
TaskTracker to update the status of its
tasks within the job tracker. |
void |
initJob(JobInProgress job)
Initialize the Job
|
JobStatus[] |
jobsToComplete()
Get the jobs that are not completed and not failed
|
void |
killJob(JobID jobid)
Kill the indicated job
|
void |
killJob(JobID jobid)
Kill the job identified by jobid
|
boolean |
killTask(TaskAttemptID taskId,
boolean shouldFail)
Kill indicated task attempt.
|
boolean |
killTask(TaskAttemptID taskid,
boolean shouldFail)
Mark the task attempt identified by taskid to be killed
|
void |
removeJobInProgressListener(org.apache.hadoop.mapred.JobInProgressListener listener)
Unregisters a
JobInProgressListener from this
TaskTrackerManager . |
long |
renewDelegationToken(org.apache.hadoop.security.token.Token<DelegationTokenIdentifier> token)
Renew an existing delegation token
|
void |
reportTaskTrackerError(java.lang.String taskTracker,
java.lang.String errorClass,
java.lang.String errorMessage)
Report a problem to the job tracker.
|
void |
setJobPriority(JobID jobid,
java.lang.String priority)
Set the priority of the specified job
|
JobStatus |
submitJob(JobID jobName,
java.lang.String jobSubmitDir,
org.apache.hadoop.security.Credentials ts)
Submit a Job for execution.
|
java.util.Collection<TaskTrackerStatus> |
taskTrackers() |
refreshSuperUserGroupsConfiguration, refreshUserToGroupsMappings
getGroupsForUser
refreshServiceAcl
refreshNodes, refreshQueues
static final long versionID
heartbeat(TaskTrackerStatus, boolean, boolean, boolean, short)
version 4 changed TaskReport for HADOOP-549.
version 5 introduced that removes locateMapOutputs and instead uses
getTaskCompletionEvents to figure finished maps and fetch the outputs
version 6 adds maxTasks to TaskTrackerStatus for HADOOP-1245
version 7 replaces maxTasks by maxMapTasks and maxReduceTasks in
TaskTrackerStatus for HADOOP-1274
Version 8: HeartbeatResponse is added with the next heartbeat interval.
version 9 changes the counter representation for HADOOP-2248
version 10 changes the TaskStatus representation for HADOOP-2208
version 11 changes string to JobID in getTaskCompletionEvents().
version 12 changes the counters representation for HADOOP-1915
version 13 added call getBuildVersion() for HADOOP-236
Version 14: replaced getFilesystemName with getSystemDir for HADOOP-3135
Version 15: Changed format of Task and TaskStatus for HADOOP-153
Version 16: adds ResourceStatus to TaskTrackerStatus for HADOOP-3759
Version 17: Changed format of Task and TaskStatus for HADOOP-3150
Version 18: Changed status message due to changes in TaskStatus
Version 19: Changed heartbeat to piggyback JobTracker restart information
so that the TaskTracker can synchronize itself.
Version 20: Changed status message due to changes in TaskStatus
(HADOOP-4232)
Version 21: Changed information reported in TaskTrackerStatus'
ResourceStatus and the corresponding accessor methods
(HADOOP-4035)
Version 22: Replaced parameter 'initialContact' with 'restarted'
in heartbeat method (HADOOP-4305)
Version 23: Added parameter 'initialContact' again in heartbeat method
(HADOOP-4869)
Version 24: Changed format of Task and TaskStatus for HADOOP-4759
Version 25: JobIDs are passed in response to JobTracker restart
Version 26: Added numRequiredSlots to TaskStatus for MAPREDUCE-516
Version 27: Adding node health status to TaskStatus for MAPREDUCE-211
Version 28: Adding user name to the serialized Task for use by TT.
Version 29: Adding available memory and CPU usage information on TT to
TaskTrackerStatus for MAPREDUCE-1218
Version 30: Adding disk failure to TaskTrackerStatus for MAPREDUCE-3015
Version 31: Efficient serialization format for Framework counters
(MAPREDUCE-901)
Version 32: Adding version methods for HADOOP-8209static final int TRACKERS_OK
static final int UNKNOWN_TASKTRACKER
static final long versionID
org.apache.hadoop.mapred.HeartbeatResponse heartbeat(TaskTrackerStatus status, boolean restarted, boolean initialContact, boolean acceptNewTasks, short responseId) throws java.io.IOException
TaskTracker
to update the status of its
tasks within the job tracker. JobTracker
responds with a
HeartbeatResponse
that directs the
TaskTracker
to undertake a series of 'actions'
(see TaskTrackerAction.ActionType
).
TaskTracker
must also indicate whether this is the first
interaction (since state refresh) and acknowledge the last response
it recieved from the JobTracker
status
- the status updaterestarted
- true
if the process has just started or
restarted, false
otherwiseinitialContact
- true
if this is first interaction since
'refresh', false
otherwise.acceptNewTasks
- true
if the TaskTracker
is
ready to accept new tasks to run.responseId
- the last responseId successfully acted upon by the
TaskTracker
.HeartbeatResponse
with
fresh instructions.java.io.IOException
java.lang.String getFilesystemName() throws java.io.IOException
java.io.IOException
void reportTaskTrackerError(java.lang.String taskTracker, java.lang.String errorClass, java.lang.String errorMessage) throws java.io.IOException
taskTracker
- the name of the task trackererrorClass
- the kind of error (eg. the class that was thrown)errorMessage
- the human readable error messagejava.io.IOException
- if there was a problem in communication or on the
remote sideTaskCompletionEvent[] getTaskCompletionEvents(JobID jobid, int fromEventId, int maxEvents) throws java.io.IOException
jobid
- job idfromEventId
- event id to start from.maxEvents
- the max number of events we want to look atjava.io.IOException
java.lang.String getSystemDir()
java.lang.String getBuildVersion() throws java.io.IOException
java.io.IOException
java.lang.String getVIVersion() throws java.io.IOException
java.io.IOException
JobID getNewJobId() throws java.io.IOException
java.io.IOException
JobStatus submitJob(JobID jobName, java.lang.String jobSubmitDir, org.apache.hadoop.security.Credentials ts) throws java.io.IOException
java.io.IOException
ClusterStatus getClusterStatus(boolean detailed) throws java.io.IOException
detailed
- if true then report tracker names and memory usagejava.io.IOException
org.apache.hadoop.security.authorize.AccessControlList getQueueAdmins(java.lang.String queueName) throws java.io.IOException
queueName
- java.io.IOException
void killJob(JobID jobid) throws java.io.IOException
java.io.IOException
void setJobPriority(JobID jobid, java.lang.String priority) throws java.io.IOException
jobid
- ID of the jobpriority
- Priority to be set for the jobjava.io.IOException
boolean killTask(TaskAttemptID taskId, boolean shouldFail) throws java.io.IOException
taskId
- the id of the task to kill.shouldFail
- if true the task is failed and added to failed tasks list, otherwise
it is just killed, w/o affecting job failure status.java.io.IOException
JobProfile getJobProfile(JobID jobid) throws java.io.IOException
java.io.IOException
JobStatus getJobStatus(JobID jobid) throws java.io.IOException
java.io.IOException
Counters getJobCounters(JobID jobid) throws java.io.IOException
java.io.IOException
TaskReport[] getMapTaskReports(JobID jobid) throws java.io.IOException
java.io.IOException
TaskReport[] getReduceTaskReports(JobID jobid) throws java.io.IOException
java.io.IOException
TaskReport[] getCleanupTaskReports(JobID jobid) throws java.io.IOException
java.io.IOException
TaskReport[] getSetupTaskReports(JobID jobid) throws java.io.IOException
java.io.IOException
java.lang.String getFilesystemName() throws java.io.IOException
java.io.IOException
JobStatus[] jobsToComplete() throws java.io.IOException
java.io.IOException
JobStatus[] getAllJobs() throws java.io.IOException
java.io.IOException
TaskCompletionEvent[] getTaskCompletionEvents(JobID jobid, int fromEventId, int maxEvents) throws java.io.IOException
jobid
- job idfromEventId
- event id to start from.maxEvents
- the max number of events we want to look atjava.io.IOException
java.lang.String[] getTaskDiagnostics(TaskAttemptID taskId) throws java.io.IOException
taskId
- the id of the taskjava.io.IOException
java.lang.String getSystemDir()
java.lang.String getStagingAreaDir() throws java.io.IOException
java.io.IOException
JobQueueInfo[] getQueues() throws java.io.IOException
java.io.IOException
JobQueueInfo getQueueInfo(java.lang.String queue) throws java.io.IOException
queue
- Queue Namejava.io.IOException
JobStatus[] getJobsFromQueue(java.lang.String queue) throws java.io.IOException
queue
- Queue namejava.io.IOException
org.apache.hadoop.mapred.QueueAclsInfo[] getQueueAclsForCurrentUser() throws java.io.IOException
java.io.IOException
org.apache.hadoop.security.token.Token<DelegationTokenIdentifier> getDelegationToken(org.apache.hadoop.io.Text renewer) throws java.io.IOException, java.lang.InterruptedException
renewer
- the user other than the creator (if any) that can renew the
tokenjava.io.IOException
java.lang.InterruptedException
long renewDelegationToken(org.apache.hadoop.security.token.Token<DelegationTokenIdentifier> token) throws java.io.IOException, java.lang.InterruptedException
token
- the token to renewjava.io.IOException
java.lang.InterruptedException
void cancelDelegationToken(org.apache.hadoop.security.token.Token<DelegationTokenIdentifier> token) throws java.io.IOException, java.lang.InterruptedException
token
- the token to canceljava.io.IOException
java.lang.InterruptedException
java.util.Collection<TaskTrackerStatus> taskTrackers()
TaskTrackerStatus
for the tasktrackers
being managed.int getNumberOfUniqueHosts()
ClusterStatus getClusterStatus()
void addJobInProgressListener(org.apache.hadoop.mapred.JobInProgressListener listener)
JobInProgressListener
for updates from this
TaskTrackerManager
.jobInProgressListener
- the JobInProgressListener
to addvoid removeJobInProgressListener(org.apache.hadoop.mapred.JobInProgressListener listener)
JobInProgressListener
from this
TaskTrackerManager
.jobInProgressListener
- the JobInProgressListener
to removeorg.apache.hadoop.mapred.QueueManager getQueueManager()
QueueManager
which manages the queues in this
TaskTrackerManager
.QueueManager
int getNextHeartbeatInterval()
TaskTracker
s.TaskTracker
svoid killJob(JobID jobid) throws java.io.IOException
jobid
- java.io.IOException
JobInProgress getJob(JobID jobid)
jobid
- void initJob(JobInProgress job)
job
- JobInProgress objectvoid failJob(JobInProgress job)
job
- JobInProgress objectboolean killTask(TaskAttemptID taskid, boolean shouldFail) throws java.io.IOException
taskid
- task to killshouldFail
- whether to count the task as failedjava.io.IOException
Copyright © 2009 The Apache Software Foundation