@InterfaceAudience.Private @InterfaceStability.Unstable public class LocalJobRunner extends Object implements org.apache.hadoop.mapreduce.protocol.ClientProtocol
Modifier and Type | Field and Description |
---|---|
static String |
INTERMEDIATE_DATA_ENCRYPTION_ALGO |
static String |
LOCAL_MAX_MAPS
The maximum number of map tasks to run in parallel in LocalJobRunner
|
static String |
LOCAL_MAX_REDUCES
The maximum number of reduce tasks to run in parallel in LocalJobRunner
|
static org.slf4j.Logger |
LOG |
Constructor and Description |
---|
LocalJobRunner(org.apache.hadoop.conf.Configuration conf) |
LocalJobRunner(org.apache.hadoop.mapred.JobConf conf)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
cancelDelegationToken(org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier> token) |
org.apache.hadoop.mapreduce.TaskTrackerInfo[] |
getActiveTrackers()
Get all active trackers in cluster.
|
org.apache.hadoop.mapreduce.JobStatus[] |
getAllJobs() |
org.apache.hadoop.mapreduce.TaskTrackerInfo[] |
getBlacklistedTrackers()
Get all blacklisted trackers in cluster.
|
org.apache.hadoop.mapreduce.QueueInfo[] |
getChildQueues(String queueName) |
org.apache.hadoop.mapreduce.ClusterMetrics |
getClusterMetrics() |
org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier> |
getDelegationToken(org.apache.hadoop.io.Text renewer) |
String |
getFilesystemName() |
org.apache.hadoop.mapreduce.Counters |
getJobCounters(org.apache.hadoop.mapreduce.JobID id) |
String |
getJobHistoryDir() |
org.apache.hadoop.mapreduce.JobStatus |
getJobStatus(org.apache.hadoop.mapreduce.JobID id) |
org.apache.hadoop.mapreduce.Cluster.JobTrackerStatus |
getJobTrackerStatus() |
static int |
getLocalMaxRunningMaps(org.apache.hadoop.mapreduce.JobContext job) |
static int |
getLocalMaxRunningReduces(org.apache.hadoop.mapreduce.JobContext job) |
org.apache.hadoop.mapreduce.v2.LogParams |
getLogFileParams(org.apache.hadoop.mapreduce.JobID jobID,
org.apache.hadoop.mapreduce.TaskAttemptID taskAttemptID) |
org.apache.hadoop.mapreduce.JobID |
getNewJobID() |
org.apache.hadoop.ipc.ProtocolSignature |
getProtocolSignature(String protocol,
long clientVersion,
int clientMethodsHash) |
long |
getProtocolVersion(String protocol,
long clientVersion) |
org.apache.hadoop.mapreduce.QueueInfo |
getQueue(String queue) |
org.apache.hadoop.mapreduce.QueueAclsInfo[] |
getQueueAclsForCurrentUser() |
org.apache.hadoop.security.authorize.AccessControlList |
getQueueAdmins(String queueName) |
org.apache.hadoop.mapreduce.QueueInfo[] |
getQueues() |
org.apache.hadoop.mapreduce.QueueInfo[] |
getRootQueues() |
String |
getStagingAreaDir() |
String |
getSystemDir() |
org.apache.hadoop.mapreduce.TaskCompletionEvent[] |
getTaskCompletionEvents(org.apache.hadoop.mapreduce.JobID jobid,
int fromEventId,
int maxEvents) |
String[] |
getTaskDiagnostics(org.apache.hadoop.mapreduce.TaskAttemptID taskid)
Returns the diagnostic information for a particular task in the given job.
|
org.apache.hadoop.mapreduce.TaskReport[] |
getTaskReports(org.apache.hadoop.mapreduce.JobID id,
org.apache.hadoop.mapreduce.TaskType type) |
long |
getTaskTrackerExpiryInterval() |
void |
killJob(org.apache.hadoop.mapreduce.JobID id) |
boolean |
killTask(org.apache.hadoop.mapreduce.TaskAttemptID taskId,
boolean shouldFail)
|
long |
renewDelegationToken(org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier> token) |
void |
setJobPriority(org.apache.hadoop.mapreduce.JobID id,
String jp) |
static void |
setLocalMaxRunningMaps(org.apache.hadoop.mapreduce.JobContext job,
int maxMaps)
Set the max number of map tasks to run concurrently in the LocalJobRunner.
|
static void |
setLocalMaxRunningReduces(org.apache.hadoop.mapreduce.JobContext job,
int maxReduces)
Set the max number of reduce tasks to run concurrently in the LocalJobRunner.
|
org.apache.hadoop.mapreduce.JobStatus |
submitJob(org.apache.hadoop.mapreduce.JobID jobid,
String jobSubmitDir,
org.apache.hadoop.security.Credentials credentials) |
public static final org.slf4j.Logger LOG
public static final String LOCAL_MAX_MAPS
public static final String LOCAL_MAX_REDUCES
public static final String INTERMEDIATE_DATA_ENCRYPTION_ALGO
public LocalJobRunner(org.apache.hadoop.conf.Configuration conf) throws IOException
IOException
@Deprecated public LocalJobRunner(org.apache.hadoop.mapred.JobConf conf) throws IOException
IOException
public long getProtocolVersion(String protocol, long clientVersion)
getProtocolVersion
in interface org.apache.hadoop.ipc.VersionedProtocol
public org.apache.hadoop.ipc.ProtocolSignature getProtocolSignature(String protocol, long clientVersion, int clientMethodsHash) throws IOException
getProtocolSignature
in interface org.apache.hadoop.ipc.VersionedProtocol
IOException
public org.apache.hadoop.mapreduce.JobID getNewJobID()
getNewJobID
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
public org.apache.hadoop.mapreduce.JobStatus submitJob(org.apache.hadoop.mapreduce.JobID jobid, String jobSubmitDir, org.apache.hadoop.security.Credentials credentials) throws IOException
submitJob
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
IOException
public void killJob(org.apache.hadoop.mapreduce.JobID id)
killJob
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
public void setJobPriority(org.apache.hadoop.mapreduce.JobID id, String jp) throws IOException
setJobPriority
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
IOException
public boolean killTask(org.apache.hadoop.mapreduce.TaskAttemptID taskId, boolean shouldFail) throws IOException
killTask
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
IOException
public org.apache.hadoop.mapreduce.TaskReport[] getTaskReports(org.apache.hadoop.mapreduce.JobID id, org.apache.hadoop.mapreduce.TaskType type)
getTaskReports
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
public org.apache.hadoop.mapreduce.JobStatus getJobStatus(org.apache.hadoop.mapreduce.JobID id)
getJobStatus
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
public org.apache.hadoop.mapreduce.Counters getJobCounters(org.apache.hadoop.mapreduce.JobID id)
getJobCounters
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
public String getFilesystemName() throws IOException
getFilesystemName
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
IOException
public org.apache.hadoop.mapreduce.ClusterMetrics getClusterMetrics()
getClusterMetrics
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
public org.apache.hadoop.mapreduce.Cluster.JobTrackerStatus getJobTrackerStatus()
getJobTrackerStatus
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
public long getTaskTrackerExpiryInterval() throws IOException, InterruptedException
getTaskTrackerExpiryInterval
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
IOException
InterruptedException
public org.apache.hadoop.mapreduce.TaskTrackerInfo[] getActiveTrackers() throws IOException, InterruptedException
getActiveTrackers
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
IOException
InterruptedException
public org.apache.hadoop.mapreduce.TaskTrackerInfo[] getBlacklistedTrackers() throws IOException, InterruptedException
getBlacklistedTrackers
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
IOException
InterruptedException
public org.apache.hadoop.mapreduce.TaskCompletionEvent[] getTaskCompletionEvents(org.apache.hadoop.mapreduce.JobID jobid, int fromEventId, int maxEvents) throws IOException
getTaskCompletionEvents
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
IOException
public org.apache.hadoop.mapreduce.JobStatus[] getAllJobs()
getAllJobs
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
public String[] getTaskDiagnostics(org.apache.hadoop.mapreduce.TaskAttemptID taskid) throws IOException
getTaskDiagnostics
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
IOException
public String getSystemDir()
getSystemDir
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
ClientProtocol.getSystemDir()
public org.apache.hadoop.security.authorize.AccessControlList getQueueAdmins(String queueName) throws IOException
getQueueAdmins
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
IOException
ClientProtocol.getQueueAdmins(String)
public String getStagingAreaDir() throws IOException
getStagingAreaDir
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
IOException
ClientProtocol.getStagingAreaDir()
public String getJobHistoryDir()
getJobHistoryDir
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
public org.apache.hadoop.mapreduce.QueueInfo[] getChildQueues(String queueName) throws IOException
getChildQueues
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
IOException
public org.apache.hadoop.mapreduce.QueueInfo[] getRootQueues() throws IOException
getRootQueues
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
IOException
public org.apache.hadoop.mapreduce.QueueInfo[] getQueues() throws IOException
getQueues
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
IOException
public org.apache.hadoop.mapreduce.QueueInfo getQueue(String queue) throws IOException
getQueue
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
IOException
public org.apache.hadoop.mapreduce.QueueAclsInfo[] getQueueAclsForCurrentUser() throws IOException
getQueueAclsForCurrentUser
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
IOException
public static void setLocalMaxRunningMaps(org.apache.hadoop.mapreduce.JobContext job, int maxMaps)
job
- the job to configuremaxMaps
- the maximum number of map tasks to allow.public static int getLocalMaxRunningMaps(org.apache.hadoop.mapreduce.JobContext job)
public static void setLocalMaxRunningReduces(org.apache.hadoop.mapreduce.JobContext job, int maxReduces)
job
- the job to configuremaxReduces
- the maximum number of reduce tasks to allow.public static int getLocalMaxRunningReduces(org.apache.hadoop.mapreduce.JobContext job)
public void cancelDelegationToken(org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier> token) throws IOException, InterruptedException
cancelDelegationToken
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
IOException
InterruptedException
public org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier> getDelegationToken(org.apache.hadoop.io.Text renewer) throws IOException, InterruptedException
getDelegationToken
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
IOException
InterruptedException
public long renewDelegationToken(org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier> token) throws IOException, InterruptedException
renewDelegationToken
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
IOException
InterruptedException
public org.apache.hadoop.mapreduce.v2.LogParams getLogFileParams(org.apache.hadoop.mapreduce.JobID jobID, org.apache.hadoop.mapreduce.TaskAttemptID taskAttemptID) throws IOException, InterruptedException
getLogFileParams
in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
IOException
InterruptedException
Copyright © 2008–2024 Apache Software Foundation. All rights reserved.