程序包 | 说明 |
---|---|
org.apache.hadoop.filecache | |
org.apache.hadoop.mapred |
A software framework for easily writing applications which process vast
amounts of data (multi-terabyte data-sets) parallelly on large clusters
(thousands of nodes) built of commodity hardware in a reliable, fault-tolerant
manner.
|
org.apache.hadoop.mapreduce | |
org.apache.hadoop.mapreduce.lib.jobcontrol | |
org.apache.hadoop.mapreduce.security.token | |
org.apache.hadoop.mapreduce.server.tasktracker.userlogs | |
org.apache.hadoop.mapreduce.split | |
org.apache.hadoop.tools.rumen |
Rumen is a data extraction and analysis tool built for
Apache Hadoop.
|
限定符和类型 | 方法和说明 |
---|---|
protected TaskDistributedCacheManager |
TrackerDistributedCacheManager.getTaskDistributedCacheManager(JobID jobId) |
TaskDistributedCacheManager |
TrackerDistributedCacheManager.newTaskDistributedCacheManager(JobID jobId,
Configuration taskConf) |
void |
TrackerDistributedCacheManager.removeTaskDistributedCacheManager(JobID jobId) |
void |
TrackerDistributedCacheManager.setArchiveSizes(JobID jobId,
long[] sizes)
Set the sizes for any archives, files, or directories in the private
distributed cache.
|
限定符和类型 | 类和说明 |
---|---|
class |
JobID
JobID represents the immutable and unique identifier for
the job.
|
限定符和类型 | 方法和说明 |
---|---|
void |
UserLogCleaner.deleteJobLogs(JobID jobid) |
static JobID |
JobID.downgrade(JobID old)
Downgrade a new JobID to an old one
|
static File |
TaskLog.getJobDir(JobID jobid)
Get the user log directory for the job jobid.
|
void |
JobLocalizer.localizeJobFiles(JobID jobid,
JobConf jConf,
Path localJobFile,
Path localJobTokenFile,
TaskUmbilicalProtocol taskTracker) |
void |
JobLocalizer.localizeJobFiles(JobID jobid,
JobConf jConf,
Path localJobTokenFile,
TaskUmbilicalProtocol taskTracker) |
void |
UserLogCleaner.markJobLogsForDeletion(long jobCompletionTime,
int retainHours,
JobID jobid)
Adds job user-log directory to cleanup thread to delete logs after user-log
retain hours.
|
void |
UserLogCleaner.unmarkJobFromLogDeletion(JobID jobid)
Remove job from user log deletion.
|
void |
TaskUmbilicalProtocol.updatePrivateDistributedCacheSizes(JobID jobId,
long[] sizes)
The job initializer needs to report the sizes of the archive
objects and directories in the private distributed cache.
|
void |
TaskTracker.updatePrivateDistributedCacheSizes(JobID jobId,
long[] sizes) |
构造器和说明 |
---|
JobProfile(String user,
JobID jobid,
String jobFile,
String url,
String name)
Construct a
JobProfile the userid, jobid,
job config-file, job-details url and job name. |
JobProfile(String user,
JobID jobid,
String jobFile,
String url,
String name,
String queueName)
Construct a
JobProfile the userid, jobid,
job config-file, job-details url and job name. |
TaskID(JobID jobId,
boolean isMap,
int id)
Constructs a TaskID object from given
JobID . |
限定符和类型 | 方法和说明 |
---|---|
static JobID |
JobID.forName(String str)
Construct a JobId object from given string
|
JobID |
TaskID.getJobID()
Returns the
JobID object that this tip belongs to |
JobID |
TaskAttemptID.getJobID()
Returns the
JobID object that this task attempt belongs to |
JobID |
JobContext.getJobID()
Get the unique ID for the job.
|
构造器和说明 |
---|
JobContext(Configuration conf,
JobID jobId) |
TaskID(JobID jobId,
boolean isMap,
int id)
Constructs a TaskID object from given
JobID . |
限定符和类型 | 方法和说明 |
---|---|
JobID |
ControlledJob.getMapredJobID() |
限定符和类型 | 方法和说明 |
---|---|
static void |
DelegationTokenRenewal.registerDelegationTokensForRenewal(JobID jobId,
Credentials ts,
Configuration conf) |
static void |
DelegationTokenRenewal.removeDelegationTokenRenewalForJob(JobID jobId)
removing DT for completed jobs
|
限定符和类型 | 方法和说明 |
---|---|
JobID |
JobStartedEvent.getJobID()
Get the job id.
|
JobID |
JobCompletedEvent.getJobID()
Get the job id.
|
JobID |
DeleteJobEvent.getJobID()
Get the jobid.
|
构造器和说明 |
---|
DeleteJobEvent(JobID jobid)
Create the event to delete job log directory.
|
JobCompletedEvent(JobID jobid,
long jobCompletionTime,
int retainHours)
Create the event for job completion.
|
JobStartedEvent(JobID jobid)
Create the event to inform the job has started.
|
限定符和类型 | 方法和说明 |
---|---|
static JobSplit.TaskSplitMetaInfo[] |
SplitMetaInfoReader.readSplitMetaInfo(JobID jobId,
FileSystem fs,
Configuration conf,
Path jobSubmitDir) |
限定符和类型 | 方法和说明 |
---|---|
JobID |
JobFinishedEvent.getJobid()
Get the Job ID
|
JobID |
JobUnsuccessfulCompletionEvent.getJobId()
Get the Job ID
|
JobID |
JobSubmittedEvent.getJobId()
Get the Job Id
|
JobID |
JobStatusChangedEvent.getJobId()
Get the Job Id
|
JobID |
JobPriorityChangeEvent.getJobId()
Get the Job ID
|
JobID |
JobInitedEvent.getJobId()
Get the job ID
|
JobID |
JobInfoChangeEvent.getJobId()
Get the Job ID
|
JobID |
ZombieJob.getJobID() |
JobID |
JobStory.getJobID()
Get the job ID
|
构造器和说明 |
---|
JobFinishedEvent(JobID id,
long finishTime,
int finishedMaps,
int finishedReduces,
int failedMaps,
int failedReduces,
Counters mapCounters,
Counters reduceCounters,
Counters totalCounters)
Create an event to record successful job completion
|
JobInfoChangeEvent(JobID id,
long submitTime,
long launchTime)
Create a event to record the submit and launch time of a job
|
JobInitedEvent(JobID id,
long launchTime,
int totalMaps,
int totalReduces,
String jobStatus)
Create an event to record job initialization
|
JobPriorityChangeEvent(JobID id,
JobPriority priority)
Generate an event to record changes in Job priority
|
JobStatusChangedEvent(JobID id,
String jobStatus)
Create an event to record the change in the Job Status
|
JobSubmittedEvent(JobID id,
String jobName,
String userName,
long submitTime,
String jobConfPath)
|
JobSubmittedEvent(JobID id,
String jobName,
String userName,
long submitTime,
String jobConfPath,
Map<JobACL,AccessControlList> jobACLs)
|
JobSubmittedEvent(JobID id,
String jobName,
String userName,
long submitTime,
String jobConfPath,
Map<JobACL,AccessControlList> jobACLs,
String queue,
String workflowId,
String workflowName,
String workflowNodeName,
String workflowAdjacencies)
|
JobSubmittedEvent(JobID id,
String jobName,
String userName,
long submitTime,
String jobConfPath,
Map<JobACL,AccessControlList> jobACLs,
String queue,
String workflowId,
String workflowName,
String workflowNodeName,
String workflowAdjacencies,
String workflowTags)
Create an event to record job submission
|
JobUnsuccessfulCompletionEvent(JobID id,
long finishTime,
int finishedMaps,
int finishedReduces,
String status)
Create an event to record unsuccessful completion (killed/failed) of jobs
|
Copyright © 2009 The Apache Software Foundation