Uses of Class
edu.isi.pegasus.planner.classes.Job
-
-
Uses of Job in edu.isi.pegasus.planner.catalog.site.classes
Methods in edu.isi.pegasus.planner.catalog.site.classes with parameters of type Job Modifier and Type Method Description java.lang.String
SiteStore. getInternalWorkDirectory(Job job)
This determines the working directory on remote execution pool for a particular job.java.lang.String
SiteStore. getInternalWorkDirectory(Job job, boolean onStagingSite)
This determines the working directory on remote execution pool or a staging site for a particular job. -
Uses of Job in edu.isi.pegasus.planner.catalog.site.impl.old
Methods in edu.isi.pegasus.planner.catalog.site.impl.old with parameters of type Job Modifier and Type Method Description java.lang.String
PoolInfoProvider. getExecPoolWorkDir(Job job)
This determines the working directory on remote execution pool for a particular job. -
Uses of Job in edu.isi.pegasus.planner.classes
Subclasses of Job in edu.isi.pegasus.planner.classes Modifier and Type Class Description class
AggregatedJob
This class holds all the specifics of an aggregated job.class
DAGJob
This is a data class that stores the contents of the DAG job in a DAX conforming to schema 3.0 or higher.class
DAXJob
This is a data class that stores the contents of the DAX job in a DAX conforming to schema 3.0 or higher.class
TransferJob
This is a data class that stores the contents of the transfer job that transfers the data.Methods in edu.isi.pegasus.planner.classes that return Job Modifier and Type Method Description Job
AggregatedJob. getConstituentJob(int index)
Returns a job from a particular position in the list of constituent jobsMethods in edu.isi.pegasus.planner.classes that return types with arguments of type Job Modifier and Type Method Description java.util.Iterator<Job>
AggregatedJob. constituentJobsIterator()
Returns an iterator to the constituent jobs of the AggregatedJob.Methods in edu.isi.pegasus.planner.classes with parameters of type Job Modifier and Type Method Description void
ADag. add(Job job)
This adds a new job to the ADAG object.void
AggregatedJob. add(Job job)
Adds a job to the aggregated job.void
WorkflowMetrics. decrement(Job job)
Decrement the metrics when on the basis of type of job being removedprivate void
WorkflowMetrics. decrementJobMetrics(Job job)
Decrement the metrics when on the basis of type of job.private void
WorkflowMetrics. decrementTaskMetrics(Job job)
Decrement the task metrics when on the basis of type of job.void
WorkflowMetrics. increment(Job job)
Increment the metrics when on the basis of type of job.private void
WorkflowMetrics. incrementJobMetrics(Job job)
Increment the metrics when on the basis of type of job.private void
WorkflowMetrics. incrementTaskMetrics(Job job)
Increment the metrics when on the basis of type of job.void
Job. mergeProfiles(Job job)
Merges profiles from another job to this job in a controlled fashion.boolean
ADag. remove(Job job)
Removes a particular job from the workflow.Constructors in edu.isi.pegasus.planner.classes with parameters of type Job Constructor Description AggregatedJob(Job job, int num)
The overloaded constructor.DAGJob(Job job)
The overloaded construct that constructs a DAG job by wrapping around theJob
job.DAXJob(Job job)
The overloaded construct that constructs a DAX job by wrapping around theJob
job.Job(Job job)
Overloaded constructor.TransferJob(Job job)
The overloaded construct that constructs a GRMS job by wrapping around theJob
job. -
Uses of Job in edu.isi.pegasus.planner.client
Methods in edu.isi.pegasus.planner.client that return Job Modifier and Type Method Description protected Job
CPlanner. createNoOPJob(java.lang.String name)
It creates a NoOP job that runs on the submit host.Methods in edu.isi.pegasus.planner.client with parameters of type Job Modifier and Type Method Description protected void
CPlanner. construct(Job job, java.lang.String key, java.lang.String value)
Constructs a condor variable in the condor profile namespace associated with the job. -
Uses of Job in edu.isi.pegasus.planner.cluster
Fields in edu.isi.pegasus.planner.cluster with type parameters of type Job Modifier and Type Field Description protected java.util.Map<java.lang.String,Job>
Abstract. mPartitionClusterMap
A Map that indexes the partition ID to the clustered job.protected java.util.Map<java.lang.String,Job>
Abstract. mSubInfoMap
A Map to store all the job(Job) objects indexed by their logical ID found in the dax.Methods in edu.isi.pegasus.planner.cluster that return Job Modifier and Type Method Description protected Job
Abstract. clusteredJob(Partition p)
Returns the job corresponding to a partition.protected Job
Abstract. clusteredJob(java.lang.String id)
Returns the job corresponding to a partition.protected Job
Abstract. getJob(java.lang.String id)
Returns the job object corresponding to the id of the job.Methods in edu.isi.pegasus.planner.cluster that return types with arguments of type Job Modifier and Type Method Description private java.util.List<java.util.List<Job>>
Horizontal. bestFitBinPack(java.util.List<Job> jobs, double maxTime)
Perform best fit bin packing.private java.util.List<java.util.List<Job>>
Horizontal. bestFitBinPack(java.util.List<Job> jobs, int maxBins)
Perform best fit bin packing.private java.util.Comparator<Job>
Horizontal. getBinPackingComparator()
The comparator is used to sort a collection of jobs in decreasing order of their run times as specified by the Pegasus.JOB_RUN_TIME property.Methods in edu.isi.pegasus.planner.cluster with parameters of type Job Modifier and Type Method Description protected void
Abstract. addJob(Job job)
Adds jobs to the internal map of jobs that is maintained by the clusterer.protected void
Abstract. associate(Partition p, Job job)
Maps the partition to the corresponding clustered job.int[]
Horizontal. getCollapseFactor(java.lang.String pool, Job job, int size)
Returns the collapse factor, that is used to chunk up the jobs of a particular type on a pool.private java.lang.String
Horizontal. getRunTime(Job job)
private void
Horizontal. updateReplacementTable(java.util.List jobs, Job mergedJob)
Updates the replacement table.Method parameters in edu.isi.pegasus.planner.cluster with type arguments of type Job Modifier and Type Method Description private java.util.List<java.util.List<Job>>
Horizontal. bestFitBinPack(java.util.List<Job> jobs, double maxTime)
Perform best fit bin packing.private java.util.List<java.util.List<Job>>
Horizontal. bestFitBinPack(java.util.List<Job> jobs, int maxBins)
Perform best fit bin packing.abstract void
Abstract. determineInputOutputFiles(AggregatedJob job, java.util.List<Job> orderedJobs)
Determine the input and output files of the job on the basis of the order of the constituent jobs in the AggregatedJob.void
Vertical. determineInputOutputFiles(AggregatedJob job, java.util.List<Job> orderedJobs)
Determine the input and output files of the job on the basis of the order of the constituent jobs in the AggregatedJob.protected java.lang.String
Abstract. getLogicalNameForJobs(java.util.List<Job> jobs)
Returns the logical names for the jobs.protected java.lang.String
Vertical. getLogicalNameForJobs(java.util.List<Job> jobs)
Returns null as for label based clustering we dont want the transformation name to be considered for constructing the name of the clustered jobs -
Uses of Job in edu.isi.pegasus.planner.cluster.aggregator
Methods in edu.isi.pegasus.planner.cluster.aggregator with parameters of type Job Modifier and Type Method Description protected java.lang.String
Abstract. getCommentString(Job job, int taskid)
Generates the comment string for the job .java.lang.String
MPIExec. getCPURequirementsArgument(Job job)
Looks at the profile keys associated with the job to generate the argument string fragment containing the cpu required for the job.java.lang.String
MPIExec. getExtraArguments(Job job)
Looks at the profile key for pegasus::pmc_task_arguments to determine if extra arguments are required for the task.java.lang.String
MPIExec. getMemoryRequirementsArgument(Job job)
Looks at the profile keys associated with the job to generate the argument string fragment containing the memory required for the job.java.lang.String
MPIExec. getPriorityArgument(Job job)
Looks at the profile keys associated with the job to generate the argument string fragment containing the priority to be associated for the job.protected TransformationCatalogEntry
Abstract. getTCEntry(Job job)
Helper method to get an entry from the transformation catalog for an installed executable.JobAggregator
JobAggregatorInstanceFactory. loadInstance(Job job)
Returns the appropriate handle to the JobAggregator that is to be used for a particular type of job. -
Uses of Job in edu.isi.pegasus.planner.code
Methods in edu.isi.pegasus.planner.code with parameters of type Job Modifier and Type Method Description boolean
POSTScript. construct(Job job, java.lang.String key)
Constructs the postscript that has to be invoked on the submit host after the job has executed on the remote end.boolean
GridStart. enable(Job job, boolean isGlobusJob)
Enables a job to run on the grid.void
CodeGenerator. generateCode(ADag dag, Job job)
Generates the code for a single job in the input format of the workflow executor being used.java.lang.String
GridStart. getWorkerNodeDirectory(Job job)
Returns the directory in which the job executes on the worker node.GridStart
GridStartFactory. loadGridStart(Job job, java.lang.String gridStartPath)
Loads the appropriate gridstart implementation for a job on the basis of the value of the GRIDSTART_KEY in the Pegasus namepsace.POSTScript
GridStartFactory. loadPOSTScript(Job job, GridStart gridStart)
Loads the appropriate POST Script implementation for a job on the basis of the value of the Pegasus profile GRIDSTART_KEY, and the DAGMan profile POST_SCRIPT_KEY in the Pegasus namepsace. -
Uses of Job in edu.isi.pegasus.planner.code.generator
Methods in edu.isi.pegasus.planner.code.generator with parameters of type Job Modifier and Type Method Description protected java.lang.String
Shell. generateCallToCheckExitcode(Job job, java.lang.String prefix)
Generates a call to check_exitcode function that is usedprotected java.lang.String
Shell. generateCallToExecuteJob(Job job, java.lang.String scratchDirectory, java.lang.String submitDirectory)
Generates a call to execute_job function , that is used to launch a job from the shell script.protected java.lang.String
Shell. generateCallToExecutePostScript(Job job, java.lang.String directory)
Generates a call to execute_post_script function , that is used to launch a job from the shell script.void
Braindump. generateCode(ADag dag, Job job)
Method not implemented.void
DAXReplicaStore. generateCode(ADag dag, Job job)
Not implementedvoid
MonitordNotify. generateCode(ADag dag, Job job)
Not implementedvoid
PBS. generateCode(ADag dag, Job job)
Generates the code for a single job in the input format of the workflow executor being used.void
PMC. generateCode(ADag dag, Job job)
Generates the code for a single job in the input format of the workflow executor being used.void
Shell. generateCode(ADag dag, Job job)
Generates the code for a single job in the input format of the workflow executor being used.void
Stampede. generateCode(ADag dag, Job job)
Method not implemented.void
Stork. generateCode(ADag dag, Job job)
Generates the code for a single job in the Stork format.protected void
Stampede. generateEventsForDAXTask(java.io.PrintWriter writer, ADag workflow, Job job)
Generates stampede events corresponding to jobs/tasks in the DAXprotected void
Stampede. generateEventsForExecutableJob(java.io.PrintWriter writer, ADag dag, Job job)
Generates stampede events corresponding to an executable jobprivate java.lang.String
NetloggerJobMapper. generateLogEvent(Job job, java.lang.String prefix)
Generates a log event message in the netlogger format for a jobprotected void
Stampede. generateTaskMapEvents(java.io.PrintWriter writer, ADag dag, Job job)
Generates the task.map events that link the jobs in the DAX with the jobs in the executable workflowprotected java.lang.String
Shell. getExecutionDirectory(Job job)
Returns the directory in which a job should be executed.java.lang.String
Abstract. getFileBaseName(Job job)
Returns the basename of the file to which the job is written to.java.lang.String
Stork. getFileBaseName(Job job)
Returns the basename of the file to which the job is written to.private int
NetloggerJobMapper. getTaskCount(Job job)
Returns the task count for a job.private int
Stampede. getTaskCount(Job job)
Returns the task count for a job.java.io.PrintWriter
Abstract. getWriter(Job job)
Returns an open stream to the file that is used for writing out the job information for the job.java.io.PrintWriter
HashedFile. getWriter(Job job)
Returns an open stream to the file that is used for writing out the job information for the job. -
Uses of Job in edu.isi.pegasus.planner.code.generator.condor
Methods in edu.isi.pegasus.planner.code.generator.condor that return Job Modifier and Type Method Description protected Job
CondorGenerator. constructDAGJob(java.lang.String name, java.lang.String directory, java.lang.String dagBasename)
Constructs a job that plans and submits the partitioned workflow, referred to by a Partition.protected Job
SUBDAXGenerator. constructDAGJob(Job subdaxJob, java.io.File directory, java.io.File subdaxDirectory, java.lang.String basenamePrefix)
Constructs a job that plans and submits the partitioned workflow, referred to by a Partition.Job
SUBDAXGenerator. constructPegasusPlanPrescript(Job job, PlannerOptions options, java.lang.String rootUUID, java.lang.String properties, java.lang.String log)
Constructs the pegasus plan prescript for the subdaxJob
SUBDAXGenerator. generateCode(Job job)
Generates code for a jobMethods in edu.isi.pegasus.planner.code.generator.condor with parameters of type Job Modifier and Type Method Description void
CondorStyle. apply(Job job)
Apply a style to a job.protected void
CondorGenerator. applyStyle(Job job, java.io.PrintWriter writer)
Applies a submit file style to the job, according to the fact whether the job has to be submitted directly to condor or to a remote jobmanager via CondorG and GRAM.protected Job
SUBDAXGenerator. constructDAGJob(Job subdaxJob, java.io.File directory, java.io.File subdaxDirectory, java.lang.String basenamePrefix)
Constructs a job that plans and submits the partitioned workflow, referred to by a Partition.java.lang.String
SUBDAXGenerator. constructDAGManKnobs(Job job)
Constructs Any extra arguments that need to be passed to dagman, as determined from the properties file.Job
SUBDAXGenerator. constructPegasusPlanPrescript(Job job, PlannerOptions options, java.lang.String rootUUID, java.lang.String properties, java.lang.String log)
Constructs the pegasus plan prescript for the subdaxprotected java.io.File
SUBDAXGenerator. constructPlannerPrescriptWrapper(Job dagJob, java.io.File directory, java.lang.String executable, java.lang.String arguments)
Construct a pegasus plan wrapper script that changes the directory in which pegasus-plan is launched.static void
ClassADSGenerator. generate(java.io.PrintWriter writer, ADag dag, Job job)
Writes out the classads for a job to corresponding writer stream.void
CondorGenerator. generateCode(ADag dag, Job job)
Generates the code (condor submit file) for a single job.Job
SUBDAXGenerator. generateCode(Job job)
Generates code for a jobprotected int
CondorGenerator. getJobPriority(Job job, int depth)
Computes the priority for a job based on job type and depth in the workflowjava.util.Set<java.lang.String>
SUBDAXGenerator. getParentsTransientRC(Job job)
Returns a set containing the paths to the parent dax jobs transient replica catalogs.private java.lang.String
CondorGenerator. gridstart(java.io.PrintWriter writer, Job job, boolean isGlobusJob)
This function creates the stdio handling with and without gridstart.protected void
CondorGenerator. handleCondorVarForJob(Job job)
It updates/adds the condor variables that are got through the Dax with the values specified in the properties file, pool config file or adds some variables internally.protected void
CondorGenerator. handleEnvVarForJob(Job sinfo)
It updates/adds the environment variables that are got through the Dax with the values specified in the properties file, pool config file or adds some variables internally.protected void
CondorGenerator. handleGlobusRSLForJob(Job sinfo)
It updates/adds the the Globus RSL parameters got through the dax that are in Job object.CondorStyle
CondorStyleFactory. loadInstance(Job job)
This method loads the appropriate implementing CondorStyle as specified by the user at runtime.void
CondorGenerator. populatePeriodicReleaseAndRemoveInJob(Job job)
Populates the periodic release and remove values in the job. -
Uses of Job in edu.isi.pegasus.planner.code.generator.condor.style
Methods in edu.isi.pegasus.planner.code.generator.condor.style with parameters of type Job Modifier and Type Method Description void
Condor. apply(Job job)
Applies the condor style to the job.void
CondorC. apply(Job job)
Applies the CondorC style to the job.void
CondorG. apply(Job job)
Applies the globus style to the job.void
CondorGlideIN. apply(Job job)
Applies the style to the job to be run in a condor glide in environment.void
CondorGlideinWMS. apply(Job job)
void
CreamCE. apply(Job job)
Applies the CREAM CE style to the job.void
GLite. apply(Job job)
Applies the gLite style to the job.void
SSH. apply(Job job)
Applies the CREAM CE style to the job.protected void
Abstract. applyCredentialsForJobSubmission(Job job)
Associates credentials required for job submission.protected void
Abstract. applyCredentialsForLocalExec(Job job)
Examines the credential requirements for a job and adds appropiate transfer and environment directives for the credentials to be picked up for the local jobprotected void
Abstract. applyCredentialsForRemoteExec(Job job)
Examines the credential requirements for a job and adds appropiate transfer and environment directives for the credentials to be staged and picked up by the job.protected void
Abstract. complainForCredential(Job job, java.lang.String key, java.lang.String site)
Complain if a particular credential key is not found for a siteprotected java.lang.String
CondorC. constructGridResource(Job job)
Constructs the grid_resource entry for the job.protected java.lang.String
CreamCE. constructGridResource(Job job)
Constructs the grid_resource entry for the job.protected java.lang.String
SSH. constructGridResource(Job job)
Constructs the grid_resource entry for the job.protected java.lang.String
Abstract. errorMessage(Job job, java.lang.String style, java.lang.String universe)
Constructs an error message in case of style mismatch.protected java.lang.String
GLite. getCERequirementsForJob(Job job)
Constructs the value for remote CE requirements expression for the job .protected java.lang.String
GLite. missingKeyError(Job job, java.lang.String key)
Constructs an error message in case of style mismatch.private void
Condor. wrapJobWithLocalPegasusLite(Job job)
Wraps the local universe jobs with a local Pegasus Lite wrapper to get around the Condor file IO bug for local universe job -
Uses of Job in edu.isi.pegasus.planner.code.gridstart
Methods in edu.isi.pegasus.planner.code.gridstart with parameters of type Job Modifier and Type Method Description private void
Kickstart. addCleanupPostScript(Job job, java.util.List files)
Adds a /bin/rm post constituentJob to kickstart that removes the files passed.private void
PegasusLite. associateCredentials(Job job, java.util.Collection<FileTransfer> files)
Associates credentials with the job corresponding to the files that are being transferred.private void
Kickstart. construct(Job job, java.lang.String key, java.lang.String value)
Constructs a condor variable in the condor profile namespace associated with the constituentJob.boolean
NetloggerPostScript. construct(Job job, java.lang.String key)
Constructs the postscript that has to be invoked on the submit host after the job has executed on the remote end.private void
NoGridStart. construct(Job job, java.lang.String key, java.lang.String value)
Constructs a condor variable in the condor profile namespace associated with the job.boolean
NoPOSTScript. construct(Job job, java.lang.String key)
Constructs the postscript that has to be invoked on the submit host after the job has executed on the remote end.boolean
PegasusExitCode. construct(Job job, java.lang.String key)
Constructs the postscript that has to be invoked on the submit host after the job has executed on the remote end.private void
PegasusLite. construct(Job job, java.lang.String key, java.lang.String value)
Constructs a condor variable in the condor profile namespace associated with the job.boolean
UserPOSTScript. construct(Job job, java.lang.String key)
Constructs the postscript that has to be invoked on the submit host after the job has executed on the remote end.protected java.lang.String
Kickstart. constructCleanupJob(Job job, java.lang.String workerNodeTmp)
Constructs a kickstart setup constituentJobprotected java.lang.String
Kickstart. constructPREJob(Job job, java.lang.String headNodeURLPrefix, java.lang.String headNodeDirectory, java.lang.String workerNodeDirectory, java.lang.String slsFile)
Constructs the prejob that fetches sls file, and then invokes transfer again.protected java.lang.String
Kickstart. constructSetupJob(Job job, java.lang.String workerNodeTmp)
Constructs a kickstart setup constituentJobboolean
Kickstart. enable(Job job, boolean isGlobusJob)
Enables a constituentJob to run on the grid by launching it through kickstart.protected boolean
Kickstart. enable(Job job, boolean isGlobusJob, boolean stat, boolean addPostScript, boolean partOfClusteredJob)
Enables a constituentJob to run on the grid by launching it through kickstart.boolean
NoGridStart. enable(Job job, boolean isGlobusJob)
Enables a job to run on the grid by launching it directly.boolean
PegasusLite. enable(Job job, boolean isGlobusJob)
Enables a job to run on the grid by launching it directly.private void
PegasusLite. enableForWorkerNodeExecution(Job job, boolean isGlobusJob)
Enables jobs for worker node execution.protected java.lang.String
Kickstart. getDirectory(Job job)
Returns the directory in which the job should run.protected java.lang.String
NoGridStart. getDirectory(Job job)
Returns the directory in which the job should run.private java.lang.String
Kickstart. getDirectoryKey(Job job)
Returns the exectionSiteDirectory that is associated with the constituentJob to specify the exectionSiteDirectory in which the constituentJob needs to runprivate java.lang.String
NoGridStart. getDirectoryKey(Job job)
Returns the directory that is associated with the job to specify the directory in which the job needs to runprivate java.lang.String
PegasusLite. getDirectoryKey(Job job)
Returns the directory that is associated with the job to specify the directory in which the job needs to runjava.lang.String
Kickstart. getWorkerNodeDirectory(Job job)
Returns the exectionSiteDirectory in which the constituentJob executes on the worker node.java.lang.String
NoGridStart. getWorkerNodeDirectory(Job job)
Returns the directory in which the job executes on the worker node.java.lang.String
PegasusLite. getWorkerNodeDirectory(Job job)
Returns the directory in which the job executes on the worker node.protected java.lang.String
Kickstart. handleTransferOfExecutable(Job job, java.lang.String path)
It changes the paths to the executable depending on whether we want to transfer the executable or not.protected java.lang.String
NoGridStart. handleTransferOfExecutable(Job job)
It changes the paths to the executable depending on whether we want to transfer the executable or not.private boolean
NoGridStart. removeDirectoryKey(Job job)
Returns a boolean indicating whether to remove remote directory information or not from the job.private boolean
PegasusLite. removeDirectoryKey(Job job)
Returns a boolean indicating whether to remove remote directory information or not from the job.protected boolean
Kickstart. requiresToSetDirectory(Job job)
Returns a boolean indicating whether we need to set the directory for the job or not.protected boolean
NoGridStart. requiresToSetDirectory(Job job)
Returns a boolean indicating whether we need to set the directory for the job or not.private boolean
Kickstart. useInvoke(Job job, java.lang.String executable, java.lang.StringBuffer args)
Triggers the creation of the kickstart input file, that contains the the remote executable and the arguments with which it has to be invoked.protected java.io.File
PegasusLite. wrapJobWithPegasusLite(Job job, boolean isGlobusJob)
Generates a seqexec input file for the job. -
Uses of Job in edu.isi.pegasus.planner.parser.dax
Fields in edu.isi.pegasus.planner.parser.dax declared as Job Modifier and Type Field Description private Job
DAXParser2. mCurrentJobSubInfo
Holds information regarding the current job being parsed.Fields in edu.isi.pegasus.planner.parser.dax with type parameters of type Job Modifier and Type Field Description private java.util.Map<java.lang.String,Job>
DAX2CDAG. mFileCreationMap
Map to track a LFN with the job that creates the file corresponding to the LFN.Methods in edu.isi.pegasus.planner.parser.dax with parameters of type Job Modifier and Type Method Description void
Callback. cbJob(Job job)
Callback for the job from section 4: Job's, DAX's or Dag's that list a JOB or DAX or DAG .void
DAX2CDAG. cbJob(Job job)
Callback for the job from section 2 jobs.void
DAX2Graph. cbJob(Job job)
This constructs a graph node for the job and ends up storing it in the internal map.void
DAX2LabelGraph. cbJob(Job job)
This constructs a graph node for the job and ends up storing it in the internal map.void
DAX2Metadata. cbJob(Job job)
Callback for the job from section 2 jobs.void
DAX2NewGraph. cbJob(Job job)
This constructs a graph node for the job and ends up storing it in the internal map.void
ExampleDAXCallback. cbJob(Job job)
Callback for the job from section 2 jobs.protected java.lang.String
DAXParser3. constructJobID(Job j)
Returns the id for a jobprivate TransformationCatalogEntry
DAXParser2. constructTCEntryFromJobHints(Job job)
Constructs a TC entry object from the contents of a job.private void
DAXParser2. handleJobTagStart(Job job)
Invoked when the starting of the job element is got. -
Uses of Job in edu.isi.pegasus.planner.parser.pdax
Methods in edu.isi.pegasus.planner.parser.pdax that return Job Modifier and Type Method Description protected Job
PDAX2MDAG. constructDAGJob(Partition partition, java.io.File directory, java.lang.String dax)
Constructs a job that plans and submits the partitioned workflow, referred to by a Partition.protected Job
PDAX2MDAG. getJob(java.lang.String id)
Returns the job that has been constructed for a particular partition.Methods in edu.isi.pegasus.planner.parser.pdax with parameters of type Job Modifier and Type Method Description protected java.lang.String
PDAX2MDAG. getBasenamePrefix(Job job)
Returns the basename prefix of a dagman (usually) related file for a a job that submits nested dagman.protected java.lang.String
PDAX2MDAG. getCacheFilePath(Job job)
Returns the full path to a cache file that corresponds for one partition.protected void
PDAX2MDAG. setPrescript(Job job, java.lang.String daxURL, java.lang.String log)
Sets the prescript that ends up calling to the default wrapper that introduces retry into Pegasus for a particular job.protected void
PDAX2MDAG. setPrescript(Job job, java.lang.String daxURL, java.lang.String log, java.lang.String namespace, java.lang.String name, java.lang.String version)
Sets the prescript that ends up calling to the default wrapper that introduces retry into Pegasus for a particular job. -
Uses of Job in edu.isi.pegasus.planner.refiner
Fields in edu.isi.pegasus.planner.refiner with type parameters of type Job Modifier and Type Field Description private java.util.List<Job>
DataReuseEngine. mAllDeletedJobs
List of all deleted jobs during workflow reduction.private java.util.List<Job>
TransferEngine. mDeletedJobs
Holds all the jobs deleted by the reduction algorithm.Methods in edu.isi.pegasus.planner.refiner that return Job Modifier and Type Method Description Job
ReplicaCatalogBridge. makeRCRegNode(java.lang.String regJobName, Job job, java.util.Collection files)
It constructs the Job object for the registration node, which registers the materialized files on the output pool in the RLS.Job
RemoveDirectory. makeRemoveDirJob(java.lang.String site, java.lang.String jobName)
It creates a remove directory job that creates a directory on the remote pool using the perl executable that Gaurang wrote.Job
RemoveDirectory. makeRemoveDirJob(java.lang.String site, java.lang.String jobName, java.util.List<java.lang.String> files)
It creates a remove directory job that creates a directory on the remote pool using the perl executable that Gaurang wrote.protected Job
DeployWorkerPackage. makeUntarJob(java.lang.String site, java.lang.String jobName, java.lang.String wpBasename)
It creates a untar job , that untars the worker package that is staged by the setup transfer job.Methods in edu.isi.pegasus.planner.refiner that return types with arguments of type Job Modifier and Type Method Description java.util.List<Job>
DataReuseEngine. getDeletedJobs()
This returns all the jobs deleted from the workflow after the reduction algorithm has run.java.util.List<Job>
DataReuseEngine. getDeletedLeafJobs()
This returns all the deleted jobs that happen to be leaf nodes.Methods in edu.isi.pegasus.planner.refiner with parameters of type Job Modifier and Type Method Description protected void
Engine. complainForHeadNodeURLPrefix(java.lang.String refiner, java.lang.String site, FileServerType.OPERATION operation, Job job)
Complains for head node url prefix not specifiedprivate void
TransferEngine. complainForScratchFileServer(Job job, FileServerType.OPERATION operation, java.lang.String site)
Complains for a missing head node file server on a site for a jobprivate FileTransfer
TransferEngine. constructFileTX(PegasusFile pf, Job job, java.lang.String destSiteHandle, java.lang.String path, boolean localTransfer)
Constructs the FileTransfer object on the basis of the transiency information.private java.lang.String
RemoveDirectory. getAssociatedCreateDirSite(Job job)
Returns the associated site that job is dependant on.private java.util.Vector
TransferEngine. getDeletedFileTX(java.lang.String pool, Job job)
This gets the file transfer objects corresponding to the location of files found in the replica mechanism, and transfers it to the output pool asked by the user.private void
TransferEngine. getFilesFromRC(Job job, java.util.Collection searchFiles)
It looks up the RCEngine Hashtable to lookup the locations for the files and add nodes to transfer them.private java.util.Vector
TransferEngine. getFileTX(java.lang.String destPool, Job job, boolean localTransfer)
This gets the Vector of FileTransfer objects for the files which have to be transferred to an one destination pool.private java.util.Collection<FileTransfer>[]
TransferEngine. getInterpoolFileTX(Job job, java.util.Collection<GraphNode> parents)
This gets the Vector of FileTransfer objects for all the files which have to be transferred to the destination pool in case of Interpool transfers.java.lang.String
InterPoolEngine. getStagingSite(Job job)
Returns the staging site to be used for a job.java.lang.String
TransferEngine. getStagingSite(Job job)
Returns the staging site to be used for a job.private java.lang.String
TransferEngine. getURLOnSharedScratch(SiteCatalogEntry entry, Job job, FileServerType.OPERATION operation, java.lang.String lfn)
Returns a URL on the shared scratch of the staging siteprivate void
InterPoolEngine. handleDependantExecutables(Job job)
Handles the dependant executables that need to be staged.private boolean
InterPoolEngine. incorporateHint(Job job, java.lang.String key)
It incorporates a hint in the namespace to the job.private boolean
InterPoolEngine. incorporateProfiles(Job job)
Incorporates the profiles from the various sources into the job.protected void
InterPoolEngine. logRefinerAction(Job job)
Logs the action taken by the refiner on a job as a XML fragment in the XML Producer.private void
TransferEngine. logRemoval(Job job, PegasusFile file, java.lang.String prefix, boolean removed)
Helped method for logging removal message.Job
ReplicaCatalogBridge. makeRCRegNode(java.lang.String regJobName, Job job, java.util.Collection files)
It constructs the Job object for the registration node, which registers the materialized files on the output pool in the RLS.private void
TransferEngine. processParents(Job job, java.util.Collection<GraphNode> parents)
It processes a nodes parents and determines if nodes are to be added or not.private TransformationCatalogEntry
InterPoolEngine. selectTCEntry(java.util.List entries, Job job, java.lang.String selector)
Calls out to the transformation selector to select an entry from a list of valid transformation catalog entries.private void
TransferEngine. trackInCaches(Job job)
Tracks the files created by a job in the both the planner and workflow cache The planner cache stores the put URL's and the GET URL is stored in the workflow cache.Constructor parameters in edu.isi.pegasus.planner.refiner with type arguments of type Job Constructor Description TransferEngine(ADag reducedDag, PegasusBag bag, java.util.List<Job> deletedJobs, java.util.List<Job> deletedLeafJobs)
Overloaded constructor. -
Uses of Job in edu.isi.pegasus.planner.refiner.cleanup
Methods in edu.isi.pegasus.planner.refiner.cleanup that return Job Modifier and Type Method Description Job
Cleanup. createCleanupJob(java.lang.String id, java.util.List files, Job job)
Creates a cleanup job that removes the files from remote working directory.Job
CleanupImplementation. createCleanupJob(java.lang.String id, java.util.List files, Job job)
Creates a cleanup job that removes the files from remote working directory.Job
RM. createCleanupJob(java.lang.String id, java.util.List files, Job job)
Creates a cleanup job that removes the files from remote working directory.Methods in edu.isi.pegasus.planner.refiner.cleanup with parameters of type Job Modifier and Type Method Description Job
Cleanup. createCleanupJob(java.lang.String id, java.util.List files, Job job)
Creates a cleanup job that removes the files from remote working directory.Job
CleanupImplementation. createCleanupJob(java.lang.String id, java.util.List files, Job job)
Creates a cleanup job that removes the files from remote working directory.Job
RM. createCleanupJob(java.lang.String id, java.util.List files, Job job)
Creates a cleanup job that removes the files from remote working directory.protected java.lang.String
InPlace. generateCleanupID(Job job)
Returns the identifier that is to be assigned to cleanup job.protected java.lang.String
InPlace. getSiteForCleanup(Job job)
Returns site to be used for the cleanup algorithm. -
Uses of Job in edu.isi.pegasus.planner.refiner.createdir
Methods in edu.isi.pegasus.planner.refiner.createdir that return Job Modifier and Type Method Description Job
DefaultImplementation. makeCreateDirJob(java.lang.String site, java.lang.String name, java.lang.String directoryURL)
It creates a make directoryURL job that creates a directoryURL on the remote pool using the perl executable that Gaurang wrote.Job
Implementation. makeCreateDirJob(java.lang.String site, java.lang.String name, java.lang.String directoryURL)
It creates a make directory job that creates a directory on the remote pool using the perl executable that Gaurang wrote.Job
HourGlass. makeDummyConcatJob(ADag dag)
It creates a dummy concat job that is run at the local submit host.Methods in edu.isi.pegasus.planner.refiner.createdir with parameters of type Job Modifier and Type Method Description boolean
Minimal. addDependency(Job job)
private void
HourGlass. construct(Job job, java.lang.String key, java.lang.String value)
Constructs a condor variable in the condor profile namespace associated with the job.private java.lang.String
Minimal. getAssociatedCreateDirSite(Job job)
Returns the associated site that job is dependant on.private void
HourGlass. introduceRootDependencies(ADag dag, Job newRoot)
It traverses through the root jobs of the dag and introduces a new super root node to it. -
Uses of Job in edu.isi.pegasus.planner.selector.site
Methods in edu.isi.pegasus.planner.selector.site with parameters of type Job Modifier and Type Method Description private void
Group. insert(Job job)
Inserts the job into the group map.abstract void
AbstractPerJob. mapJob(Job job, java.util.List sites)
Maps a job in the workflow to the various grid sites.void
NonJavaCallout. mapJob(Job job, java.util.List sites)
Calls out to the external site selector.void
Random. mapJob(Job job, java.util.List sites)
Maps a job in the workflow to an execution site.void
RoundRobin. mapJob(Job job, java.util.List sites)
Maps a job in the workflow to an execution site.private boolean
NonJavaCallout. parseStdOut(Job job, java.lang.String s)
Extracts the chosen site from the site selector's answer.private java.io.File
NonJavaCallout. prepareInputFile(Job job, java.util.List pools)
Writes job knowledge into the temporary file passed to the external site selector. -
Uses of Job in edu.isi.pegasus.planner.selector.site.heft
Methods in edu.isi.pegasus.planner.selector.site.heft with parameters of type Job Modifier and Type Method Description protected float
Algorithm. calculateAverageComputeTime(Job job)
Returns the average compute time in seconds for a job.protected int
Algorithm. getExpectedRuntime(Job job, TransformationCatalogEntry entry)
Return expected runtime.protected double
Algorithm. getExpectedRuntimeFromAC(Job job, TransformationCatalogEntry entry)
Return expected runtime from the AC only if the process catalog is initialized.java.lang.String
Algorithm. mapJob2ExecPool(Job job, java.util.List pools)
The call out to the site selector to determine on what pool the job should be scheduled. -
Uses of Job in edu.isi.pegasus.planner.transfer
Methods in edu.isi.pegasus.planner.transfer that return Job Modifier and Type Method Description Job
Implementation. createSetXBitJob(Job computeJob, java.util.Collection<FileTransfer> execFiles, int transferClass, int xbitIndex)
Adds the dirmanager job to the workflow, that do a chmod on the files being staged.Methods in edu.isi.pegasus.planner.transfer with parameters of type Job Modifier and Type Method Description void
Refiner. addInterSiteTXNodes(Job job, java.util.Collection files, boolean localTransfer)
Adds the inter pool transfer nodes that are required for transferring the output files of the parents to the jobs execution site.void
Refiner. addJob(Job job)
Add a new job to the workflow being refined.boolean
Implementation. addSetXBitJobs(Job computeJob, java.lang.String txJobName, java.util.Collection execFiles, int transferClass, int xbitIndex)
Adds the dirmanager job to the workflow, that do a chmod on the files being staged.void
AbstractRefiner. addStageInXFERNodes(Job job, java.util.Collection<FileTransfer> files)
Default behaviour to preserve backward compatibility when the stage in and symbolic link jobs were not separated.void
AbstractRefiner. addStageInXFERNodes(Job job, java.util.Collection<FileTransfer> files, java.util.Collection<FileTransfer> symlinkFiles)
Default behaviour to preserve backward compatibility when the stage in and symbolic link jobs were not separated.void
Refiner. addStageInXFERNodes(Job job, java.util.Collection<FileTransfer> files, java.util.Collection<FileTransfer> symLinkFiles)
Adds the stage in transfer nodes which transfer the input files for a job, from the location returned from the replica catalog to the job's execution pool.void
Refiner. addStageOutXFERNodes(Job job, java.util.Collection files, ReplicaCatalogBridge rcb, boolean localTransfer)
Adds the stageout transfer nodes, that stage data to an output site specified by the user.void
Refiner. addStageOutXFERNodes(Job job, java.util.Collection files, ReplicaCatalogBridge rcb, boolean localTransfer, boolean deletedLeaf)
Adds the stageout transfer nodes, that stage data to an output site specified by the user.Job
Implementation. createSetXBitJob(Job computeJob, java.util.Collection<FileTransfer> execFiles, int transferClass, int xbitIndex)
Adds the dirmanager job to the workflow, that do a chmod on the files being staged.TransferJob
Implementation. createTransferJob(Job job, java.lang.String site, java.util.Collection files, java.util.Collection execFiles, java.lang.String txJobName, int jobClass)
This constructs the Job object for the transfer node.java.util.Collection<FileTransfer>
SLS. determineSLSInputTransfers(Job job, java.lang.String fileName, FileServer stagingSiteServer, java.lang.String stagingSiteDirectory, java.lang.String workerNodeDirectory)
Generates a second level staging file of the input files to the worker node directory.java.util.Collection<FileTransfer>
SLS. determineSLSOutputTransfers(Job job, java.lang.String fileName, FileServer stagingSiteServer, java.lang.String stagingSiteDirectory, java.lang.String workerNodeDirectory)
Generates a second level staging file of the input files to the worker node directory.java.lang.String
SLS. getSLSInputLFN(Job job)
Returns the LFN of sls input file.java.lang.String
SLS. getSLSOutputLFN(Job job)
Returns the LFN of sls output file.java.lang.String
SLS. invocationString(Job job, java.io.File slsFile)
Constructs a command line invocation for a job, with a given sls file.boolean
SLS. modifyJobForWorkerNodeExecution(Job job, java.lang.String stagingSiteURLPrefix, java.lang.String stagingSitedirectory, java.lang.String workerNodeDirectory)
Modifies a compute job for second level staging.boolean
SLS. needsSLSInputTransfers(Job job)
Returns a boolean indicating whether it will an input file for a job to do the transfers.boolean
SLS. needsSLSOutputTransfers(Job job)
Returns a boolean indicating whether it will an output file for a job to do the transfers. -
Uses of Job in edu.isi.pegasus.planner.transfer.implementation
Methods in edu.isi.pegasus.planner.transfer.implementation that return Job Modifier and Type Method Description Job
Abstract. createNoOPJob(java.lang.String name)
It creates a NoOP job that runs on the submit host.protected Job
Abstract. createSetXBitJob(FileTransfer file, java.lang.String name)
Creates a dirmanager job, that does a chmod on the file being staged.Job
Abstract. createSetXBitJob(Job computeJob, java.util.Collection<FileTransfer> execFiles, int transferClass, int xbitIndex)
Adds the dirmanager job to the workflow, that do a chmod on the files being staged.protected Job
Abstract. createSetXBitJob(java.util.Collection<FileTransfer> files, java.lang.String name, java.lang.String site)
Creates a dirmanager job, that does a chmod on the file being staged.Methods in edu.isi.pegasus.planner.transfer.implementation with parameters of type Job Modifier and Type Method Description protected boolean
Abstract. addSetXBitJobs(Job computeJob, Job txJob, java.util.Collection execFiles)
Adds the dirmanager to the workflow, that do a chmod on the files being staged.boolean
Abstract. addSetXBitJobs(Job computeJob, java.lang.String txJobName, java.util.Collection execFiles, int transferClass)
Adds the dirmanager job to the workflow, that do a chmod on the files being staged.boolean
Abstract. addSetXBitJobs(Job computeJob, java.lang.String txJobName, java.util.Collection execFiles, int transferClass, int xbitIndex)
Adds the dirmanager job to the workflow, that do a chmod on the files being staged.protected void
Abstract. construct(Job job, java.lang.String key, java.lang.String value)
Constructs a condor variable in the condor profile namespace associated with the job.Job
Abstract. createSetXBitJob(Job computeJob, java.util.Collection<FileTransfer> execFiles, int transferClass, int xbitIndex)
Adds the dirmanager job to the workflow, that do a chmod on the files being staged.TransferJob
AbstractMultipleFTPerXFERJob. createTransferJob(Job job, java.lang.String site, java.util.Collection files, java.util.Collection execFiles, java.lang.String txJobName, int jobClass)
Constructs a general transfer job that handles multiple transfers per transfer job.TransferJob
AbstractSingleFTPerXFERJob. createTransferJob(Job job, java.lang.String site, FileTransfer file, java.util.Collection execFiles, java.lang.String txJobName, int jobClass)
Constructs a general transfer job that handles single transfers per transfer job.TransferJob
AbstractSingleFTPerXFERJob. createTransferJob(Job job, java.lang.String site, java.util.Collection files, java.util.Collection execFiles, java.lang.String txJobName, int jobClass)
Constructs a general transfer job that handles single transfers per transfer job.TransferJob
Stork. createTransferJob(Job job, FileTransfer file, java.util.Collection execFiles, java.lang.String txJobName, int jobClass)
Constructs a general transfer job that handles single transfers per transfer job. -
Uses of Job in edu.isi.pegasus.planner.transfer.refiner
Fields in edu.isi.pegasus.planner.transfer.refiner with type parameters of type Job Modifier and Type Field Description private java.util.Map<java.lang.String,Job>
Cluster. mSyncJobMap
Maps the site name to the current synch jobMethods in edu.isi.pegasus.planner.transfer.refiner that return Job Modifier and Type Method Description protected Job
Basic. createRegistrationJob(java.lang.String regJobName, Job job, java.util.Collection files, ReplicaCatalogBridge rcb)
Creates the registration jobs, which registers the materialized files on the output site in the Replica Catalog.protected Job
Empty. createRegistrationJob(java.lang.String regJobName, Job job, java.util.Collection files, ReplicaCatalogBridge rcb)
Creates the registration jobs, which registers the materialized files on the output site in the Replica Catalog.private Job
Cluster. createSyncJobBetweenLevels(java.lang.String name)
It creates a NoOP synch job that runs on the submit host.Job
Cluster. getSyncJob(java.lang.String site)
Returns the current synch job for a site.Methods in edu.isi.pegasus.planner.transfer.refiner with parameters of type Job Modifier and Type Method Description void
Basic. addInterSiteTXNodes(Job job, java.util.Collection files, boolean localTransfer)
Adds the inter pool transfer nodes that are required for transferring the output files of the parents to the jobs execution site.void
Empty. addInterSiteTXNodes(Job job, java.util.Collection files, boolean localTransfer)
Adds the inter pool transfer nodes that are required for transferring the output files of the parents to the jobs execution site.void
Basic. addJob(Job job)
Add a new job to the workflow being refined.void
Empty. addJob(Job job)
Add a new job to the workflow being refined.void
BalancedCluster. addStageInXFERNodes(Job job, boolean localTransfer, java.util.Collection files, int type, java.util.Map<java.lang.String,BalancedCluster.PoolTransfer> stageInMap, BalancedCluster.BundleValue bundleValue, Implementation implementation)
Adds the stage in transfer nodes which transfer the input files for a job, from the location returned from the replica catalog to the job's execution pool.void
BalancedCluster. addStageInXFERNodes(Job job, java.util.Collection<FileTransfer> files, java.util.Collection<FileTransfer> symlinkFiles)
Adds the stage in transfer nodes which transfer the input files for a job, from the location returned from the replica catalog to the job's execution pool.void
Basic. addStageInXFERNodes(Job job, java.util.Collection<FileTransfer> files, java.lang.String prefix, Implementation implementation)
Adds the stage in transfer nodes which transfer the input files for a job, from the location returned from the replica catalog to the job's execution pool.void
Basic. addStageInXFERNodes(Job job, java.util.Collection<FileTransfer> files, java.util.Collection<FileTransfer> symlinkFiles)
Adds the stage in transfer nodes which transfer the input files for a job, from the location returned from the replica catalog to the job's execution pool.void
Bundle. addStageInXFERNodes(Job job, boolean localTransfer, java.util.Collection files, int type, java.util.Map<java.lang.String,Bundle.PoolTransfer> stageInMap, Bundle.BundleValue bundleValue, Implementation implementation)
Adds the stage in transfer nodes which transfer the input files for a job, from the location returned from the replica catalog to the job's execution pool.void
Bundle. addStageInXFERNodes(Job job, java.util.Collection<FileTransfer> files, java.util.Collection<FileTransfer> symlinkFiles)
Adds the stage in transfer nodes which transfer the input files for a job, from the location returned from the replica catalog to the job's execution pool.void
Cluster. addStageInXFERNodes(Job job, boolean localTransfer, java.util.Collection files, int jobType, java.util.Map<java.lang.String,Bundle.PoolTransfer> stageInMap, Bundle.BundleValue cValue, Implementation implementation)
Adds the stage in transfer nodes which transfer the input files for a job, from the location returned from the replica catalog to the job's execution pool.void
Cluster. addStageInXFERNodes(Job job, java.util.Collection<FileTransfer> files, java.util.Collection<FileTransfer> symlinkFiles)
Adds the stage in transfer nodes which transfer the input files for a job, from the location returned from the replica catalog to the job's execution pool.void
Empty. addStageInXFERNodes(Job job, java.util.Collection<FileTransfer> files, java.lang.String prefix, Implementation implementation)
Adds the stage in transfer nodes which transfer the input files for a job, from the location returned from the replica catalog to the job's execution pool.void
Empty. addStageInXFERNodes(Job job, java.util.Collection<FileTransfer> files, java.util.Collection<FileTransfer> symlinkFiles)
Adds the stage in transfer nodes which transfer the input files for a job, from the location returned from the replica catalog to the job's execution pool.void
BalancedCluster. addStageOutXFERNodes(Job job, java.util.Collection files, ReplicaCatalogBridge rcb, boolean localTransfer, boolean deletedLeaf)
Adds the stageout transfer nodes, that stage data to an output site specified by the user.void
Basic. addStageOutXFERNodes(Job job, java.util.Collection files, ReplicaCatalogBridge rcb, boolean localTransfer)
Adds the stageout transfer nodes, that stage data to an output site specified by the user.void
Basic. addStageOutXFERNodes(Job job, java.util.Collection files, ReplicaCatalogBridge rcb, boolean localTransfer, boolean deletedLeaf)
Adds the stageout transfer nodes, that stage data to an output site specified by the user.void
Bundle. addStageOutXFERNodes(Job job, java.util.Collection files, ReplicaCatalogBridge rcb, boolean localTransfer, boolean deletedLeaf)
Adds the stageout transfer nodes, that stage data to an output site specified by the user.void
Empty. addStageOutXFERNodes(Job job, java.util.Collection files, ReplicaCatalogBridge rcb, boolean localTransfer)
Adds the stageout transfer nodes, that stage data to an output site specified by the user.void
Empty. addStageOutXFERNodes(Job job, java.util.Collection files, ReplicaCatalogBridge rcb, boolean localTransfer, boolean deletedLeaf)
Adds the stageout transfer nodes, that stage data to an output site specified by the user.protected void
Cluster. constructCondorKey(Job job, java.lang.String key, java.lang.String value)
Constructs a condor variable in the condor profile namespace associated with the job.protected Job
Basic. createRegistrationJob(java.lang.String regJobName, Job job, java.util.Collection files, ReplicaCatalogBridge rcb)
Creates the registration jobs, which registers the materialized files on the output site in the Replica Catalog.protected Job
Empty. createRegistrationJob(java.lang.String regJobName, Job job, java.util.Collection files, ReplicaCatalogBridge rcb)
Creates the registration jobs, which registers the materialized files on the output site in the Replica Catalog.int
BalancedCluster.BundleValue. determine(Implementation implementation, Job job)
Determines the bundle factor for a particular site on the basis of the stage in bundle value associcated with the underlying transfer transformation in the transformation catalog.int
Bundle.BundleValue. determine(Implementation implementation, Job job)
Determines the bundle factor for a particular site on the basis of the stage in bundle value associcated with the underlying transfer transformation in the transformation catalog.protected java.lang.String
BalancedCluster. getComputeJobBundleValue(Job job)
Returns the bundle value associated with a compute job as a String.protected java.lang.String
Bundle. getComputeJobBundleValue(Job job)
Returns the bundle value associated with a compute job as a String.protected java.lang.String
Cluster. getComputeJobBundleValue(Job job)
Returns the bundle value associated with a compute job as a String.protected int
Basic. getJobPriority(Job job)
Returns the priority associated with a job based on the condor profile key priority .protected void
Basic. logRefinerAction(Job computeJob, Job txJob, java.util.Collection files, java.lang.String type)
Records the refiner action into the Provenace Store as a XML fragment. -
Uses of Job in edu.isi.pegasus.planner.transfer.sls
Methods in edu.isi.pegasus.planner.transfer.sls with parameters of type Job Modifier and Type Method Description protected void
Transfer. complainForHeadNodeURLPrefix(Job job, java.lang.String site)
Complains for head node url prefix not specifiedjava.util.Collection<FileTransfer>
Condor. determineSLSInputTransfers(Job job, java.lang.String fileName, FileServer stagingSiteServer, java.lang.String stagingSiteDirectory, java.lang.String workerNodeDirectory)
Generates a second level staging file of the input files to the worker node directory.java.util.Collection<FileTransfer>
Transfer. determineSLSInputTransfers(Job job, java.lang.String fileName, FileServer stagingSiteServer, java.lang.String stagingSiteDirectory, java.lang.String workerNodeDirectory)
Generates a second level staging file of the input files to the worker node directory.java.util.Collection<FileTransfer>
Condor. determineSLSOutputTransfers(Job job, java.lang.String fileName, FileServer stagingSiteServer, java.lang.String stagingSiteDirectory, java.lang.String workerNodeDirectory)
Generates a second level staging file of the input files to the worker node directory.java.util.Collection<FileTransfer>
Transfer. determineSLSOutputTransfers(Job job, java.lang.String fileName, FileServer stagingSiteServer, java.lang.String stagingSiteDirectory, java.lang.String workerNodeDirectory)
Generates a second level staging file of the input files to the worker node directory.java.lang.String
Condor. getSLSInputLFN(Job job)
Returns the LFN of sls input file.java.lang.String
Transfer. getSLSInputLFN(Job job)
Returns the LFN of sls input file.java.lang.String
Condor. getSLSOutputLFN(Job job)
Returns the LFN of sls output file.java.lang.String
Transfer. getSLSOutputLFN(Job job)
Returns the LFN of sls output file.java.lang.String
Condor. invocationString(Job job, java.io.File slsFile)
Constructs a command line invocation for a job, with a given sls file.java.lang.String
Transfer. invocationString(Job job, java.io.File slsFile)
Constructs a command line invocation for a job, with a given sls file.boolean
Condor. modifyJobForFirstLevelStaging(Job job, java.lang.String submitDir, java.lang.String slsInputLFN, java.lang.String slsOutputLFN)
Modifies a job for the first level staging to headnode.This is to add any files that needs to be staged to the head node for a job specific to the SLS implementation.boolean
Condor. modifyJobForWorkerNodeExecution(Job job, java.lang.String stagingSiteURLPrefix, java.lang.String stagingSiteDirectory, java.lang.String workerNodeDirectory)
Modifies a compute job for second level staging.boolean
Transfer. modifyJobForWorkerNodeExecution(Job job, java.lang.String stagingSiteURLPrefix, java.lang.String stagingSitedirectory, java.lang.String workerNodeDirectory)
Modifies a compute job for second level staging.boolean
Condor. needsSLSInputTransfers(Job job)
Returns a boolean indicating whether it will an input file for a job to do the transfers.boolean
Transfer. needsSLSInputTransfers(Job job)
Returns a boolean indicating whether it will an input file for a job to do the transfers.boolean
Condor. needsSLSOutputTransfers(Job job)
Returns a boolean indicating whether it will an output file for a job to do the transfers.boolean
Transfer. needsSLSOutputTransfers(Job job)
Returns a boolean indicating whether it will an output file for a job to do the transfers.
-