Skip to content
This repository has been archived by the owner on Jun 20, 2024. It is now read-only.

Commit

Permalink
Adding a new execution system.
Browse files Browse the repository at this point in the history
This system can be used with the --experimental-execution option.
  • Loading branch information
nh13 committed Jun 11, 2017
1 parent fa1c4c4 commit dddfbb9
Show file tree
Hide file tree
Showing 24 changed files with 4,167 additions and 3 deletions.
3 changes: 3 additions & 0 deletions core/src/main/scala/dagr/core/cmdline/DagrCoreMain.scala
Original file line number Diff line number Diff line change
Expand Up @@ -108,6 +108,8 @@ class DagrCoreArgs(
val report: Option[Path] = None,
@arg(doc = "Provide an top-like interface for tasks with the give delay in seconds. This suppress info logging.")
var interactive: Boolean = false,
@arg(doc = "Use the experimental execution system.")
val experimentalExecution: Boolean = false,
@arg(doc = "Attempt to replay using the provided replay log")
val replayLog: Option[FilePath] = None
) extends LazyLogging {
Expand Down Expand Up @@ -157,6 +159,7 @@ class DagrCoreArgs(
val resources = SystemResources(cores = cores.map(Cores(_)), totalMemory = memory.map(Memory(_)))
this.executor = Some(
Executor(
experimentalExecution = experimentalExecution,
resources = resources,
scriptsDirectory = scriptsDirectory,
logDirectory = logDirectory
Expand Down
12 changes: 10 additions & 2 deletions core/src/main/scala/dagr/core/exec/Executor.scala
Original file line number Diff line number Diff line change
Expand Up @@ -27,6 +27,8 @@ package dagr.core.exec

import com.fulcrumgenomics.commons.CommonsDef.{DirPath, yieldAndThen}
import dagr.core.execsystem.{SystemResources, TaskManager}
import dagr.core.execsystem2.GraphExecutor
import dagr.core.execsystem2.local.LocalTaskExecutor
import dagr.core.reporting.ReportingDef.{TaskLogger, TaskRegister}
import dagr.core.reporting.{FinalStatusReporter, TaskStatusLogger}
import dagr.core.tasksystem.Task
Expand All @@ -37,11 +39,17 @@ import scala.concurrent.ExecutionContext

object Executor {
/** Create a new executor. */
def apply(resources: SystemResources,
def apply(experimentalExecution: Boolean,
resources: SystemResources,
scriptsDirectory: Option[DirPath],
logDirectory: Option[DirPath]
)(implicit ex: ExecutionContext): Executor = {
new TaskManager(taskManagerResources=resources, scriptsDirectory=scriptsDirectory, logDirectory=logDirectory)
if (experimentalExecution) {
GraphExecutor(new LocalTaskExecutor(systemResources=resources, scriptsDirectory=scriptsDirectory, logDirectory=logDirectory))
}
else {
new TaskManager(taskManagerResources=resources, scriptsDirectory=scriptsDirectory, logDirectory=logDirectory)
}
}
}

Expand Down
1 change: 0 additions & 1 deletion core/src/main/scala/dagr/core/execsystem/TaskTracker.scala
Original file line number Diff line number Diff line change
Expand Up @@ -30,7 +30,6 @@ import com.fulcrumgenomics.commons.collection.BiMap
import com.fulcrumgenomics.commons.util.LazyLogging
import dagr.core.DagrDef._
import dagr.core.execsystem.TaskStatus._
import dagr.core.reporting.ReportingDef.TaskRegister
import dagr.core.tasksystem.Task
import dagr.core.tasksystem.Task.{TaskStatus => RootTaskStatus}

Expand Down
145 changes: 145 additions & 0 deletions core/src/main/scala/dagr/core/execsystem2/DependencyGraph.scala
Original file line number Diff line number Diff line change
@@ -0,0 +1,145 @@
/*
* The MIT License
*
* Copyright (c) 2017 Fulcrum Genomics LLC
*
* Permission is hereby granted, free of charge, to any person obtaining a copy
* of this software and associated documentation files (the "Software"), to deal
* in the Software without restriction, including without limitation the rights
* to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
* copies of the Software, and to permit persons to whom the Software is
* furnished to do so, subject to the following conditions:
*
* The above copyright notice and this permission notice shall be included in
* all copies or substantial portions of the Software.
*
* THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
* IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
* FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
* AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
* LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
* OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
* THE SOFTWARE.
*
*/

package dagr.core.execsystem2

import java.util.concurrent.CountDownLatch
import java.util.concurrent.atomic.AtomicInteger

import com.fulcrumgenomics.commons.util.LazyLogging
import dagr.core.exec.ExecDef
import dagr.core.tasksystem.Task

/**
* A trait that classes that track and update dependencies on tasks should implement.
*/
trait DependencyGraph {

/** Add a task to the dependency graph and returns true if the task has no dependencies, false otherwise. */
def add(task: Task): Boolean

/** None if the task was already added, true if the task was added and has no dependencies, false otherwise. */
def maybeAdd(task: Task): Option[Boolean]

/** Removes this task as a dependency for all other tasks in this dependency graph. The task should not depend on
* any tasks, and all tasks that depend on it will have their dependency on this task removed.
*/
def remove(task: Task): Seq[Task]

/** Returns None if the task is not in the graph, true if it has dependencies, false otherwise.
*/
def hasDependencies(task: Task): Option[Boolean]

/** Returns true if the task is in the graph, false otherwise. */
def contains(task: Task): Boolean

/** The number of tasks in the dependency graph. */
def size: Int

/** Throws an exception if there is a cycle in the dependency graph. The exception may have relevant debug
* information.
* @param task
*/
def exceptIfCyclicalDependency(task: Task): Unit
}

object DependencyGraph {
/** Returns a default implementation of a dependency graph (i.e. a [[SimpleDependencyGraph]])*/
def apply(): DependencyGraph = new SimpleDependencyGraph
}

/**
* A very simple dependency graph that uses a [[CountDownLatch]] on the number of dependencies for a [[Task]] to
* block until a task has no dependencies.
*/
private class SimpleDependencyGraph extends DependencyGraph with LazyLogging {
import scala.collection.mutable

/** The map of tasks to the number of remaining unsatisfied dependencies. */
private val graph: mutable.Map[Task, AtomicInteger] = ExecDef.concurrentMap()

/** Adds the task to the dependency graph. Returns None if the task has already been added, true if the task
* has no dependencies, and false if it has dependencies. */
def maybeAdd(task: Task): Option[Boolean] = this.synchronized { if (contains(task)) None else Some(add(task)) }

/** Adds the task to the dependency graph. The task should not already be part of the graph. Returns true if the task
* has no dependencies, and false if it has dependencies */
def add(task: Task): Boolean = this.synchronized {
require(!this.graph.contains(task), s"Task '${task.name}' is already part of the dependency graph")
this.graph.put(task, new AtomicInteger(task.tasksDependedOn.size))
!this.hasDependencies(task).get
}

/** Removes this task from the dependency graph. It should not depend on any tasks itself, and all tasks that depend
* on it will have their dependency on this task removed. Returns any dependent task that now has no more
* dependencies.
*/
def remove(task: Task): Seq[Task] = {
require(task.tasksDependedOn.isEmpty,
s"Removing a task '${task.name}' from the dependency graph that has dependencies: "
+ task.tasksDependedOn.map(_.name).mkString(", "))
// remove this as a dependency for all other tasks that depend on this task
task.tasksDependingOnThisTask.flatMap { dependent =>
dependent.synchronized {
require(this.graph.contains(dependent), s"Dependent '${dependent.name}' not in the dependency graph")
task !=> dependent
val latch = this.graph(dependent)
if (latch.decrementAndGet() == 0) Some(dependent) else None
}
}.toSeq
}

/** Returns None if the task is not part of the graph, true if the task has dependencies, false otherwise. */
def hasDependencies(task: Task): Option[Boolean] = {
this.graph.get(task).map { e => e.get() > 0 }
}

/** Returns true if the task is part of the graph, false otherwise. */
def contains(task: Task): Boolean = this.graph.contains(task)

/** Returns the number of tasks in the graph. */
def size: Int = this.graph.size

// NB: I think that the dependents in Task could be updated while were are doing this! How do we synchronize? Do we
// have a global lock in the Task object?
/** Throws an exception if there is a cycle in the dependency graph. The exception may have relevant debug
* information.
* @param task
*/
def exceptIfCyclicalDependency(task: Task): Unit = this.synchronized {
// check for cycles
if (Task.hasCycle(task)) {
logger.error("Task was part of a graph that had a cycle")
for (component <- Task.findStronglyConnectedComponents(task = task)) {
if (Task.isComponentACycle(component = component)) {
logger.error("Tasks were part of a strongly connected component with a cycle: "
+ component.map(t => s"'${t.name}'").mkString(", "))
}
}
throw new IllegalArgumentException(s"Task was part of a graph that had a cycle '${task.name}'")
}
}
}

Loading

0 comments on commit dddfbb9

Please sign in to comment.