@InterfaceAudience.Private
@InterfaceStability.Stable
public interface ClientProtocol
extends org.apache.hadoop.ipc.VersionedProtocol
| Modifier and Type | Field and Description | 
|---|---|
| static long | versionID | 
| Modifier and Type | Method and Description | 
|---|---|
| void | cancelDelegationToken(org.apache.hadoop.security.token.Token<DelegationTokenIdentifier> token)Cancel a delegation token. | 
| TaskTrackerInfo[] | getActiveTrackers()Get all active trackers in cluster. | 
| JobStatus[] | getAllJobs()Get all the jobs submitted. | 
| TaskTrackerInfo[] | getBlacklistedTrackers()Get all blacklisted trackers in cluster. | 
| QueueInfo[] | getChildQueues(String queueName)Returns immediate children of queueName. | 
| ClusterMetrics | getClusterMetrics()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. | 
| String | getFilesystemName()A MapReduce system always operates on a single filesystem. | 
| Counters | getJobCounters(JobID jobid)Grab the current job counters | 
| String | getJobHistoryDir()Gets the directory location of the completed job history files. | 
| JobStatus | getJobStatus(JobID jobid)Grab a handle to a job that is already known to the JobTracker. | 
| Cluster.JobTrackerStatus | getJobTrackerStatus()Get the JobTracker's status. | 
| LogParams | getLogFileParams(JobID jobID,
                TaskAttemptID taskAttemptID)Gets the location of the log file for a job if no taskAttemptId is
 specified, otherwise gets the log location for the taskAttemptId. | 
| JobID | getNewJobID()Allocate a name for the job. | 
| QueueInfo | getQueue(String queueName)Gets scheduling information associated with the particular Job queue | 
| QueueAclsInfo[] | getQueueAclsForCurrentUser()Gets the Queue ACLs for current user | 
| org.apache.hadoop.security.authorize.AccessControlList | getQueueAdmins(String queueName)Get the administrators of the given job-queue. | 
| QueueInfo[] | getQueues()Gets set of Queues associated with the Job Tracker | 
| QueueInfo[] | getRootQueues()Gets the root level queues. | 
| String | getStagingAreaDir()Get a hint from the JobTracker 
 where job-specific files are to be placed. | 
| 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. | 
| String[] | getTaskDiagnostics(TaskAttemptID taskId)Get the diagnostics for a given task in a given job | 
| TaskReport[] | getTaskReports(JobID jobid,
              TaskType type)Grab a bunch of info on the tasks that make up the job | 
| long | getTaskTrackerExpiryInterval() | 
| void | killJob(JobID jobid)Kill the indicated job | 
| boolean | killTask(TaskAttemptID taskId,
        boolean shouldFail)Kill indicated task attempt. | 
| long | renewDelegationToken(org.apache.hadoop.security.token.Token<DelegationTokenIdentifier> token)Renew an existing delegation token | 
| void | setJobPriority(JobID jobid,
              String priority)Set the priority of the specified job | 
| JobStatus | submitJob(JobID jobId,
         String jobSubmitDir,
         org.apache.hadoop.security.Credentials ts)Submit a Job for execution. | 
static final long versionID
JobID getNewJobID() throws IOException, InterruptedException
IOExceptionInterruptedExceptionJobStatus submitJob(JobID jobId, String jobSubmitDir, org.apache.hadoop.security.Credentials ts) throws IOException, InterruptedException
IOExceptionInterruptedExceptionClusterMetrics getClusterMetrics() throws IOException, InterruptedException
IOExceptionInterruptedExceptionCluster.JobTrackerStatus getJobTrackerStatus() throws IOException, InterruptedException
Cluster.JobTrackerStatus of the JobTrackerIOExceptionInterruptedExceptionlong getTaskTrackerExpiryInterval()
                                  throws IOException,
                                         InterruptedException
IOExceptionInterruptedExceptionorg.apache.hadoop.security.authorize.AccessControlList getQueueAdmins(String queueName) throws IOException
queueName - IOExceptionvoid killJob(JobID jobid) throws IOException, InterruptedException
IOExceptionInterruptedExceptionvoid setJobPriority(JobID jobid, String priority) throws IOException, InterruptedException
jobid - ID of the jobpriority - Priority to be set for the jobIOExceptionInterruptedExceptionboolean killTask(TaskAttemptID taskId, boolean shouldFail) throws IOException, InterruptedException
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.IOExceptionInterruptedExceptionJobStatus getJobStatus(JobID jobid) throws IOException, InterruptedException
IOExceptionInterruptedExceptionCounters getJobCounters(JobID jobid) throws IOException, InterruptedException
IOExceptionInterruptedExceptionTaskReport[] getTaskReports(JobID jobid, TaskType type) throws IOException, InterruptedException
IOExceptionInterruptedExceptionString getFilesystemName() throws IOException, InterruptedException
IOExceptionInterruptedExceptionJobStatus[] getAllJobs() throws IOException, InterruptedException
IOExceptionInterruptedExceptionTaskCompletionEvent[] getTaskCompletionEvents(JobID jobid, int fromEventId, int maxEvents) throws IOException, InterruptedException
jobid - job idfromEventId - event id to start from.maxEvents - the max number of events we want to look atIOExceptionInterruptedExceptionString[] getTaskDiagnostics(TaskAttemptID taskId) throws IOException, InterruptedException
taskId - the id of the taskIOExceptionInterruptedExceptionTaskTrackerInfo[] getActiveTrackers() throws IOException, InterruptedException
IOExceptionInterruptedExceptionTaskTrackerInfo[] getBlacklistedTrackers() throws IOException, InterruptedException
IOExceptionInterruptedExceptionString getSystemDir() throws IOException, InterruptedException
IOExceptionInterruptedExceptionString getStagingAreaDir() throws IOException, InterruptedException
IOExceptionInterruptedExceptionString getJobHistoryDir() throws IOException, InterruptedException
IOExceptionInterruptedExceptionQueueInfo[] getQueues() throws IOException, InterruptedException
IOExceptionInterruptedExceptionQueueInfo getQueue(String queueName) throws IOException, InterruptedException
queueName - Queue NameIOExceptionInterruptedExceptionQueueAclsInfo[] getQueueAclsForCurrentUser() throws IOException, InterruptedException
IOExceptionInterruptedExceptionQueueInfo[] getRootQueues() throws IOException, InterruptedException
IOExceptionInterruptedExceptionQueueInfo[] getChildQueues(String queueName) throws IOException, InterruptedException
queueName - IOExceptionInterruptedExceptionorg.apache.hadoop.security.token.Token<DelegationTokenIdentifier> getDelegationToken(org.apache.hadoop.io.Text renewer) throws IOException, InterruptedException
renewer - the user other than the creator (if any) that can renew the 
        tokenIOExceptionInterruptedExceptionlong renewDelegationToken(org.apache.hadoop.security.token.Token<DelegationTokenIdentifier> token) throws IOException, InterruptedException
token - the token to renewIOExceptionInterruptedExceptionvoid cancelDelegationToken(org.apache.hadoop.security.token.Token<DelegationTokenIdentifier> token) throws IOException, InterruptedException
token - the token to cancelIOExceptionInterruptedExceptionLogParams getLogFileParams(JobID jobID, TaskAttemptID taskAttemptID) throws IOException, InterruptedException
jobID - the jobId.taskAttemptID - the taskAttemptId.IOExceptionInterruptedExceptionCopyright © 2022 Apache Software Foundation. All rights reserved.