public class JobTracker extends java.lang.Object implements JTProtocols, JobTrackerMXBean
Modifier and Type | Class and Description |
---|---|
static class |
JobTracker.IllegalStateException
A client tried to submit a job before the Job Tracker was ready.
|
static class |
JobTracker.State |
Modifier and Type | Field and Description |
---|---|
static long |
COUNTER_UPDATE_INTERVAL |
static long |
DEFAULT_DISK_HEALTH_CHECK_INTERVAL
How often TaskTracker needs to check the health of its disks, if not
configured using mapred.disk.healthChecker.interval
|
static long |
DELEGATION_KEY_UPDATE_INTERVAL_DEFAULT |
static java.lang.String |
DELEGATION_KEY_UPDATE_INTERVAL_KEY |
static long |
DELEGATION_TOKEN_MAX_LIFETIME_DEFAULT |
static java.lang.String |
DELEGATION_TOKEN_MAX_LIFETIME_KEY |
static long |
DELEGATION_TOKEN_RENEW_INTERVAL_DEFAULT |
static java.lang.String |
DELEGATION_TOKEN_RENEW_INTERVAL_KEY |
static int |
FILE_NOT_FOUND |
static java.lang.String |
FOR_REDUCE_TASK
The reduce task number for which this map output is being transferred
|
static java.lang.String |
FROM_MAP_TASK
The map task from which the map output data is being transferred
|
static int |
HEARTBEAT_INTERVAL_MIN_DEFAULT |
static java.lang.String |
JT_KEYTAB_FILE |
static java.lang.String |
JT_USER_NAME |
static org.apache.commons.logging.Log |
LOG |
static java.lang.String |
MAP_OUTPUT_LENGTH
The custom http header used for the map output length.
|
static java.lang.String |
MAPRED_CLUSTER_MAP_MEMORY_MB_PROPERTY |
static java.lang.String |
MAPRED_CLUSTER_REDUCE_MEMORY_MB_PROPERTY |
static java.lang.String |
MAX_USER_JOBCONF_SIZE_KEY
the config key for max user jobconf size
|
static java.lang.String |
RAW_MAP_OUTPUT_LENGTH
The custom http header used for the "raw" map output length.
|
static java.lang.String |
SHUFFLE_SSL_ADDRESS_DEFAULT |
static java.lang.String |
SHUFFLE_SSL_ADDRESS_KEY |
static boolean |
SHUFFLE_SSL_ENABLED_DEFAULT |
static java.lang.String |
SHUFFLE_SSL_ENABLED_KEY |
static int |
SHUFFLE_SSL_PORT_DEFAULT |
static java.lang.String |
SHUFFLE_SSL_PORT_KEY |
static int |
SUCCESS |
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 |
static java.lang.String |
WORKDIR |
versionID
versionID
versionID
versionID
Modifier and Type | Method and Description |
---|---|
java.util.Collection<TaskTrackerStatus> |
activeTaskTrackers()
Get the active task tracker statuses in the cluster
|
void |
addJobInProgressListener(org.apache.hadoop.mapred.JobInProgressListener listener)
Registers a
JobInProgressListener for updates from this
TaskTrackerManager . |
java.util.Collection<TaskTrackerStatus> |
blacklistedTaskTrackers()
Get the blacklisted task tracker statuses in the cluster
|
void |
cancelDelegationToken(org.apache.hadoop.security.token.Token<DelegationTokenIdentifier> token)
Discard a current delegation token.
|
java.util.Vector<JobInProgress> |
completedJobs() |
java.util.Vector<JobInProgress> |
failedJobs() |
void |
failJob(JobInProgress job)
Fail a job and inform the listeners.
|
static java.net.InetSocketAddress |
getAddress(org.apache.hadoop.conf.Configuration conf) |
java.lang.String |
getAliveNodesInfoJson() |
JobStatus[] |
getAllJobs()
Get all the jobs submitted.
|
java.lang.String |
getAssignedTracker(TaskAttemptID taskId)
Get tracker name for a given task id.
|
java.lang.String |
getBlacklistedNodesInfoJson() |
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
|
org.apache.hadoop.mapred.Clock |
getClock() |
ClusterMetrics |
getClusterMetrics() |
ClusterStatus |
getClusterStatus()
Deprecated.
|
ClusterStatus |
getClusterStatus(boolean detailed)
Get the current status of the cluster
|
java.util.List<JobInProgress> |
getCompletedJobs() |
JobConf |
getConf()
Returns a handle to the JobTracker's Configuration
|
java.lang.String |
getConfigVersion() |
org.apache.hadoop.security.token.Token<DelegationTokenIdentifier> |
getDelegationToken(org.apache.hadoop.io.Text renewer)
Get a new delegation token.
|
DelegationTokenSecretManager |
getDelegationTokenSecretManager() |
java.util.List<JobInProgress> |
getFailedJobs() |
java.lang.String |
getFilesystemName()
Grab the local fs name
|
java.lang.String[] |
getGroupsForUser(java.lang.String user)
Get the groups which are mapped to the given user.
|
java.lang.String |
getHostname() |
int |
getInfoPort() |
static java.lang.Class<? extends org.apache.hadoop.mapred.JobTrackerInstrumentation> |
getInstrumentationClass(org.apache.hadoop.conf.Configuration conf) |
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.
|
java.lang.String |
getJobTrackerMachine() |
static java.lang.String |
getLocalJobFilePath(JobID jobId)
Get the localized job file path on the job trackers local file system
|
TaskReport[] |
getMapTaskReports(JobID jobid)
Grab a bunch of info on the map tasks that make up the job
|
JobID |
getNewJobId()
Allocates a new JobId string.
|
int |
getNextHeartbeatInterval()
Calculates next heartbeat interval using cluster size.
|
org.apache.hadoop.net.Node |
getNode(java.lang.String name)
Return the Node in the network topology that corresponds to the hostname
|
java.util.Collection<org.apache.hadoop.net.Node> |
getNodesAtMaxLevel()
Returns a collection of nodes at the max level
|
int |
getNumberOfUniqueHosts() |
int |
getNumResolvedTaskTrackers() |
int |
getNumTaskCacheLevels() |
static org.apache.hadoop.net.Node |
getParentNode(org.apache.hadoop.net.Node node,
int level) |
org.apache.hadoop.ipc.ProtocolSignature |
getProtocolSignature(java.lang.String protocol,
long clientVersion,
int clientMethodsHash) |
long |
getProtocolVersion(java.lang.String protocol,
long clientVersion) |
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
|
java.lang.String |
getQueueInfoJson() |
org.apache.hadoop.mapred.QueueManager |
getQueueManager()
Return the
QueueManager associated with the JobTracker. |
JobQueueInfo[] |
getQueues()
Gets set of Job Queues associated with the Job Tracker
|
long |
getRecoveryDuration()
How long the jobtracker took to recover from restart.
|
TaskReport[] |
getReduceTaskReports(JobID jobid)
Grab a bunch of info on the reduce tasks that make up the job
|
java.util.List<JobInProgress> |
getRunningJobs()
Version that is called from a timer thread, and therefore needs to be
careful to synchronize.
|
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.
|
long |
getStartTime() |
java.lang.String |
getSummaryJson() |
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.
|
java.lang.String[] |
getTaskDiagnostics(TaskAttemptID taskId)
Get the diagnostics for a given task
|
TaskTracker |
getTaskTracker(java.lang.String trackerID) |
TaskTrackerStatus |
getTaskTrackerStatus(java.lang.String trackerID) |
int |
getThreadCount() |
TaskInProgress |
getTip(TaskID tipid)
Returns specified TaskInProgress, or null.
|
int |
getTotalSubmissions() |
java.lang.String |
getTrackerIdentifier()
Get the unique identifier (ie.
|
int |
getTrackerPort() |
java.lang.String |
getVersion() |
java.lang.String |
getVIVersion()
Returns the VersionInfo version of the JobTracker
|
boolean |
hasRecovered()
Whether the JT has recovered upon restart
|
boolean |
hasRestarted()
Whether the JT has restarted
|
org.apache.hadoop.mapred.HeartbeatResponse |
heartbeat(TaskTrackerStatus status,
boolean restarted,
boolean initialContact,
boolean acceptNewTasks,
short responseId)
The periodic heartbeat mechanism between the
TaskTracker and
the JobTracker . |
void |
initJob(JobInProgress job)
Initialize the Job
|
boolean |
isBlacklisted(java.lang.String trackerID)
Whether the tracker is blacklisted or not
|
JobStatus[] |
jobsToComplete()
Get the jobs that are not completed and not failed
|
void |
killJob(JobID jobid)
Kill the indicated job
|
boolean |
killTask(TaskAttemptID taskid,
boolean shouldFail)
Kill indicated task attempt.
|
static void |
main(java.lang.String[] argv)
Start the JobTracker process.
|
void |
offerService()
Run forever
|
void |
refreshNodes()
Rereads the config to get hosts and exclude list file names.
|
void |
refreshQueues()
Refresh the queue acls in use currently.
|
void |
refreshServiceAcl()
Refresh the service-level authorization policy in-effect.
|
void |
refreshSuperUserGroupsConfiguration()
Refresh superuser proxy group list
|
void |
refreshUserToGroupsMappings()
Refresh user to group mappings.
|
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 a delegation token to extend its lifetime.
|
void |
reportTaskTrackerError(java.lang.String taskTracker,
java.lang.String errorClass,
java.lang.String errorMessage)
Report a problem to the job tracker.
|
org.apache.hadoop.net.Node |
resolveAndAddToTopology(java.lang.String name) |
java.util.Vector<JobInProgress> |
runningJobs() |
static void |
setInstrumentationClass(org.apache.hadoop.conf.Configuration conf,
java.lang.Class<? extends org.apache.hadoop.mapred.JobTrackerInstrumentation> t) |
void |
setJobPriority(JobID jobid,
java.lang.String priority)
Set the priority of the specified job
|
static JobTracker |
startTracker(JobConf conf)
Start the JobTracker with given configuration.
|
static JobTracker |
startTracker(JobConf conf,
java.lang.String identifier) |
void |
stopTracker() |
JobStatus |
submitJob(JobID jobId,
java.lang.String jobSubmitDir,
org.apache.hadoop.security.Credentials ts)
JobTracker.submitJob() kicks off a new job.
|
java.util.List<java.util.List<java.lang.String>> |
taskTrackerNames()
Get the active and blacklisted task tracker names in the cluster.
|
java.util.Collection<TaskTrackerStatus> |
taskTrackers()
Get all the task trackers in the cluster
|
public static final java.lang.String MAX_USER_JOBCONF_SIZE_KEY
public static final java.lang.String DELEGATION_KEY_UPDATE_INTERVAL_KEY
public static final long DELEGATION_KEY_UPDATE_INTERVAL_DEFAULT
public static final java.lang.String DELEGATION_TOKEN_RENEW_INTERVAL_KEY
public static final long DELEGATION_TOKEN_RENEW_INTERVAL_DEFAULT
public static final java.lang.String DELEGATION_TOKEN_MAX_LIFETIME_KEY
public static final long DELEGATION_TOKEN_MAX_LIFETIME_DEFAULT
public static final java.lang.String SHUFFLE_SSL_ENABLED_KEY
public static final boolean SHUFFLE_SSL_ENABLED_DEFAULT
public static final java.lang.String SHUFFLE_SSL_ADDRESS_KEY
public static final java.lang.String SHUFFLE_SSL_ADDRESS_DEFAULT
public static final java.lang.String SHUFFLE_SSL_PORT_KEY
public static final int SHUFFLE_SSL_PORT_DEFAULT
public static final org.apache.commons.logging.Log LOG
public static final java.lang.String JT_USER_NAME
public static final java.lang.String JT_KEYTAB_FILE
public static final java.lang.String MAPRED_CLUSTER_MAP_MEMORY_MB_PROPERTY
public static final java.lang.String MAPRED_CLUSTER_REDUCE_MEMORY_MB_PROPERTY
public static final int HEARTBEAT_INTERVAL_MIN_DEFAULT
public static final long COUNTER_UPDATE_INTERVAL
public static final long DEFAULT_DISK_HEALTH_CHECK_INTERVAL
public static final int SUCCESS
public static final int FILE_NOT_FOUND
public static final java.lang.String MAP_OUTPUT_LENGTH
public static final java.lang.String RAW_MAP_OUTPUT_LENGTH
public static final java.lang.String FROM_MAP_TASK
public static final java.lang.String FOR_REDUCE_TASK
public static final java.lang.String WORKDIR
public 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-8209public static final int TRACKERS_OK
public static final int UNKNOWN_TASKTRACKER
public static final long versionID
public org.apache.hadoop.mapred.Clock getClock()
public static JobTracker startTracker(JobConf conf) throws java.io.IOException, java.lang.InterruptedException
zero
.conf
- configuration for the JobTracker.java.io.IOException
java.lang.InterruptedException
public static JobTracker startTracker(JobConf conf, java.lang.String identifier) throws java.io.IOException, java.lang.InterruptedException
java.io.IOException
java.lang.InterruptedException
public void stopTracker() throws java.io.IOException
java.io.IOException
public long getProtocolVersion(java.lang.String protocol, long clientVersion) throws java.io.IOException
getProtocolVersion
in interface org.apache.hadoop.ipc.VersionedProtocol
java.io.IOException
public org.apache.hadoop.ipc.ProtocolSignature getProtocolSignature(java.lang.String protocol, long clientVersion, int clientMethodsHash) throws java.io.IOException
getProtocolSignature
in interface org.apache.hadoop.ipc.VersionedProtocol
java.io.IOException
public DelegationTokenSecretManager getDelegationTokenSecretManager()
public boolean hasRestarted()
public boolean hasRecovered()
public long getRecoveryDuration()
public static java.lang.Class<? extends org.apache.hadoop.mapred.JobTrackerInstrumentation> getInstrumentationClass(org.apache.hadoop.conf.Configuration conf)
public static void setInstrumentationClass(org.apache.hadoop.conf.Configuration conf, java.lang.Class<? extends org.apache.hadoop.mapred.JobTrackerInstrumentation> t)
public static java.net.InetSocketAddress getAddress(org.apache.hadoop.conf.Configuration conf)
public void offerService() throws java.lang.InterruptedException, java.io.IOException
java.lang.InterruptedException
java.io.IOException
public int getTotalSubmissions()
public java.lang.String getJobTrackerMachine()
public java.lang.String getTrackerIdentifier()
public int getTrackerPort()
public int getInfoPort()
public long getStartTime()
public java.util.Vector<JobInProgress> runningJobs()
public java.util.List<JobInProgress> getRunningJobs()
public java.util.Vector<JobInProgress> failedJobs()
public java.util.List<JobInProgress> getFailedJobs()
public java.util.Vector<JobInProgress> completedJobs()
public java.util.List<JobInProgress> getCompletedJobs()
public java.util.Collection<TaskTrackerStatus> taskTrackers()
Collection
of TaskTrackerStatus
public java.util.Collection<TaskTrackerStatus> activeTaskTrackers()
Collection
of active TaskTrackerStatus
public java.util.List<java.util.List<java.lang.String>> taskTrackerNames()
public java.util.Collection<TaskTrackerStatus> blacklistedTaskTrackers()
Collection
of blacklisted TaskTrackerStatus
public boolean isBlacklisted(java.lang.String trackerID)
trackerID
- public TaskTrackerStatus getTaskTrackerStatus(java.lang.String trackerID)
public TaskTracker getTaskTracker(java.lang.String trackerID)
public org.apache.hadoop.net.Node resolveAndAddToTopology(java.lang.String name)
public java.util.Collection<org.apache.hadoop.net.Node> getNodesAtMaxLevel()
public static org.apache.hadoop.net.Node getParentNode(org.apache.hadoop.net.Node node, int level)
public org.apache.hadoop.net.Node getNode(java.lang.String name)
public int getNumTaskCacheLevels()
public int getNumResolvedTaskTrackers()
public int getNumberOfUniqueHosts()
public void addJobInProgressListener(org.apache.hadoop.mapred.JobInProgressListener listener)
JobInProgressListener
for updates from this
TaskTrackerManager
.public void removeJobInProgressListener(org.apache.hadoop.mapred.JobInProgressListener listener)
JobInProgressListener
from this
TaskTrackerManager
.public org.apache.hadoop.mapred.QueueManager getQueueManager()
QueueManager
associated with the JobTracker.QueueManager
public java.lang.String getVIVersion() throws java.io.IOException
java.io.IOException
public java.lang.String getBuildVersion() throws java.io.IOException
java.io.IOException
public org.apache.hadoop.mapred.HeartbeatResponse heartbeat(TaskTrackerStatus status, boolean restarted, boolean initialContact, boolean acceptNewTasks, short responseId) throws java.io.IOException
TaskTracker
and
the JobTracker
.
The JobTracker
processes the status information sent by the
TaskTracker
and responds with instructions to start/stop
tasks or jobs, and also 'reset' instructions during contingencies.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
public int getNextHeartbeatInterval()
public java.lang.String getFilesystemName() throws java.io.IOException
java.io.IOException
public JobConf getConf()
public 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 sidepublic JobID getNewJobId() throws java.io.IOException
java.io.IOException
public JobStatus submitJob(JobID jobId, java.lang.String jobSubmitDir, org.apache.hadoop.security.Credentials ts) throws java.io.IOException
java.io.IOException
public java.lang.String getStagingAreaDir() throws java.io.IOException
java.io.IOException
JobSubmissionProtocol.getStagingAreaDir()
@Deprecated public ClusterStatus getClusterStatus()
getClusterStatus(boolean)
public ClusterStatus getClusterStatus(boolean detailed)
detailed
- if true then report tracker names and memory usagepublic ClusterMetrics getClusterMetrics()
public void killJob(JobID jobid) throws java.io.IOException
java.io.IOException
JobSubmissionProtocol.killJob(org.apache.hadoop.mapred.JobID)
public 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
public 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
public 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
public void initJob(JobInProgress job)
job
- JobInProgress objectpublic void failJob(JobInProgress job)
job
- JobInProgress objectpublic 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
public JobProfile getJobProfile(JobID jobid)
public JobStatus getJobStatus(JobID jobid)
public Counters getJobCounters(JobID jobid) throws java.io.IOException
java.io.IOException
public TaskReport[] getMapTaskReports(JobID jobid) throws java.io.IOException
java.io.IOException
public TaskReport[] getReduceTaskReports(JobID jobid) throws java.io.IOException
java.io.IOException
public TaskReport[] getCleanupTaskReports(JobID jobid) throws java.io.IOException
java.io.IOException
public TaskReport[] getSetupTaskReports(JobID jobid) throws java.io.IOException
java.io.IOException
public 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
public java.lang.String[] getTaskDiagnostics(TaskAttemptID taskId) throws java.io.IOException
taskId
- the id of the taskjava.io.IOException
public TaskInProgress getTip(TaskID tipid)
public 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
JobSubmissionProtocol.killTask(TaskAttemptID, boolean)
public java.lang.String getAssignedTracker(TaskAttemptID taskId)
taskId
- the name of the taskpublic JobStatus[] jobsToComplete()
public JobStatus[] getAllJobs()
JobSubmissionProtocol.getAllJobs()
public java.lang.String getSystemDir()
JobSubmissionProtocol.getSystemDir()
public org.apache.hadoop.security.authorize.AccessControlList getQueueAdmins(java.lang.String queueName) throws java.io.IOException
java.io.IOException
JobSubmissionProtocol.getQueueAdmins(String)
public JobInProgress getJob(JobID jobid)
public void refreshNodes() throws java.io.IOException
refreshNodes
in interface AdminOperationsProtocol
java.io.IOException
public static java.lang.String getLocalJobFilePath(JobID jobId)
jobId
- id of the jobpublic static void main(java.lang.String[] argv) throws java.io.IOException, java.lang.InterruptedException
java.io.IOException
java.lang.InterruptedException
public JobQueueInfo[] getQueues() throws java.io.IOException
java.io.IOException
public JobQueueInfo getQueueInfo(java.lang.String queue) throws java.io.IOException
queue
- Queue Namejava.io.IOException
public JobStatus[] getJobsFromQueue(java.lang.String queue) throws java.io.IOException
queue
- Queue namejava.io.IOException
public org.apache.hadoop.mapred.QueueAclsInfo[] getQueueAclsForCurrentUser() throws java.io.IOException
java.io.IOException
public void refreshServiceAcl() throws java.io.IOException
RefreshAuthorizationPolicyProtocol
refreshServiceAcl
in interface RefreshAuthorizationPolicyProtocol
java.io.IOException
public void refreshSuperUserGroupsConfiguration()
RefreshUserMappingsProtocol
refreshSuperUserGroupsConfiguration
in interface RefreshUserMappingsProtocol
public java.lang.String[] getGroupsForUser(java.lang.String user) throws java.io.IOException
GetUserMappingsProtocol
getGroupsForUser
in interface GetUserMappingsProtocol
user
- The user to get the groups for.java.io.IOException
public void refreshUserToGroupsMappings() throws java.io.IOException
RefreshUserMappingsProtocol
refreshUserToGroupsMappings
in interface RefreshUserMappingsProtocol
java.io.IOException
public void refreshQueues() throws java.io.IOException
AdminOperationsProtocol
refreshQueues
in interface AdminOperationsProtocol
java.io.IOException
public java.lang.String getHostname()
getHostname
in interface JobTrackerMXBean
public java.lang.String getVersion()
getVersion
in interface JobTrackerMXBean
public java.lang.String getConfigVersion()
getConfigVersion
in interface JobTrackerMXBean
public int getThreadCount()
getThreadCount
in interface JobTrackerMXBean
public java.lang.String getSummaryJson()
getSummaryJson
in interface JobTrackerMXBean
public java.lang.String getAliveNodesInfoJson()
getAliveNodesInfoJson
in interface JobTrackerMXBean
public java.lang.String getBlacklistedNodesInfoJson()
getBlacklistedNodesInfoJson
in interface JobTrackerMXBean
public java.lang.String getQueueInfoJson()
getQueueInfoJson
in interface JobTrackerMXBean
Copyright © 2009 The Apache Software Foundation