You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@taverna.apache.org by re...@apache.org on 2015/03/23 17:38:08 UTC

[24/51] [partial] incubator-taverna-engine git commit:

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/invocation/ProcessIdentifierException.java
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/invocation/ProcessIdentifierException.java b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/invocation/ProcessIdentifierException.java
deleted file mode 100644
index 93cc35a..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/invocation/ProcessIdentifierException.java
+++ /dev/null
@@ -1,48 +0,0 @@
-/*******************************************************************************
- * Copyright (C) 2007 The University of Manchester   
- * 
- *  Modifications to the initial code base are copyright of their
- *  respective authors, or their employers as appropriate.
- * 
- *  This program is free software; you can redistribute it and/or
- *  modify it under the terms of the GNU Lesser General Public License
- *  as published by the Free Software Foundation; either version 2.1 of
- *  the License, or (at your option) any later version.
- *    
- *  This program is distributed in the hope that it will be useful, but
- *  WITHOUT ANY WARRANTY; without even the implied warranty of
- *  MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the GNU
- *  Lesser General Public License for more details.
- *    
- *  You should have received a copy of the GNU Lesser General Public
- *  License along with this program; if not, write to the Free Software
- *  Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307
- ******************************************************************************/
-package net.sf.taverna.t2.invocation;
-
-/**
- * Thrown when attempting to create an invalid process identifier, either by
- * popping an empty one (this by definition has no parents) or by pushing a
- * local name including a colon ':' character.
- * 
- * @author Tom Oinn
- */
-public class ProcessIdentifierException extends RuntimeException {
-	private static final long serialVersionUID = -221443591753067425L;
-
-	public ProcessIdentifierException() {
-		super();
-	}
-
-	public ProcessIdentifierException(String message, Throwable cause) {
-		super(message, cause);
-	}
-
-	public ProcessIdentifierException(String message) {
-		super(message);
-	}
-
-	public ProcessIdentifierException(Throwable cause) {
-		super(cause);
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/invocation/TokenOrderException.java
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/invocation/TokenOrderException.java b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/invocation/TokenOrderException.java
deleted file mode 100644
index 2754e03..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/invocation/TokenOrderException.java
+++ /dev/null
@@ -1,49 +0,0 @@
-/*******************************************************************************
- * Copyright (C) 2007 The University of Manchester   
- * 
- *  Modifications to the initial code base are copyright of their
- *  respective authors, or their employers as appropriate.
- * 
- *  This program is free software; you can redistribute it and/or
- *  modify it under the terms of the GNU Lesser General Public License
- *  as published by the Free Software Foundation; either version 2.1 of
- *  the License, or (at your option) any later version.
- *    
- *  This program is distributed in the hope that it will be useful, but
- *  WITHOUT ANY WARRANTY; without even the implied warranty of
- *  MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the GNU
- *  Lesser General Public License for more details.
- *    
- *  You should have received a copy of the GNU Lesser General Public
- *  License along with this program; if not, write to the Free Software
- *  Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307
- ******************************************************************************/
-package net.sf.taverna.t2.invocation;
-
-/**
- * Thrown when tokens are supplied in an invalid order. Examples of this are
- * where duplicate indices are supplied in the same token stream or where list
- * items are emitted at a point where the individual members haven't been fully
- * populated.
- * 
- * @author Tom Oinn
- */
-public class TokenOrderException extends Exception {
-	public TokenOrderException() {
-		super();
-	}
-
-	public TokenOrderException(String arg0, Throwable arg1) {
-		super(arg0, arg1);
-	}
-
-	public TokenOrderException(String arg0) {
-		super(arg0);
-	}
-
-	public TokenOrderException(Throwable arg0) {
-		super(arg0);
-	}
-
-	private static final long serialVersionUID = -7870614853928171878L;
-}

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/invocation/TreeCache.java
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/invocation/TreeCache.java b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/invocation/TreeCache.java
deleted file mode 100644
index 0279bdf..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/invocation/TreeCache.java
+++ /dev/null
@@ -1,200 +0,0 @@
-/*******************************************************************************
- * Copyright (C) 2007 The University of Manchester   
- * 
- *  Modifications to the initial code base are copyright of their
- *  respective authors, or their employers as appropriate.
- * 
- *  This program is free software; you can redistribute it and/or
- *  modify it under the terms of the GNU Lesser General Public License
- *  as published by the Free Software Foundation; either version 2.1 of
- *  the License, or (at your option) any later version.
- *    
- *  This program is distributed in the hope that it will be useful, but
- *  WITHOUT ANY WARRANTY; without even the implied warranty of
- *  MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the GNU
- *  Lesser General Public License for more details.
- *    
- *  You should have received a copy of the GNU Lesser General Public
- *  License along with this program; if not, write to the Free Software
- *  Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307
- ******************************************************************************/
-package net.sf.taverna.t2.invocation;
-
-import java.util.ArrayList;
-import java.util.List;
-
-import net.sf.taverna.t2.workflowmodel.processor.activity.Job;
-
-/**
- * Tree cache for jobs waiting to be combined and dispatched down the iteration
- * system
- * 
- * @author Tom Oinn
- */
-public class TreeCache {
-	private NamedNode root = null;
-	private int indexDepth = -1;
-
-	/**
-	 * Show the tree structure, printing each node recursively
-	 */
-	@Override
-	public synchronized String toString() {
-		if (root == null)
-			return "No root node defined.";
-		StringBuilder sb = new StringBuilder();
-		printNode(root, sb, "");
-		return sb.toString();
-	}
-	
-	private synchronized void printNode(NamedNode node, StringBuilder sb, String indent) {
-		sb.append(indent).append("Node (").append(node.contents).append(")\n");
-		String newIndent = indent + "  ";
-		for (NamedNode child : node.children)
-			if (child == null)
-				sb.append(newIndent).append("null\n");
-			else
-				printNode(child, sb, newIndent);
-	}
-	
-	public class NamedNode {
-		public Job contents = null;
-		public List<NamedNode> children = new ArrayList<>();
-
-		public void insertJob(Job j) {
-			insertJobAt(j, j.getIndex());
-		}
-
-		private void insertJobAt(Job j, int[] position) {
-			if (position.length == 0) {
-				this.contents = j;
-				return;
-			}
-			int firstIndex = position[0];
-			if (firstIndex >= children.size())
-				// Pad with blank NamedNode objects
-				for (int i = children.size(); i <= firstIndex; i++)
-					children.add(null);
-			NamedNode child = children.get(firstIndex);
-			if (child == null) {
-				child = new NamedNode();
-				children.set(firstIndex, child);
-			}
-
-			int[] newTarget = new int[position.length - 1];
-			for (int i = 1; i < position.length; i++)
-				newTarget[i - 1] = position[i];
-			child.insertJobAt(j, newTarget);
-		}
-
-		public NamedNode childAt(int i) {
-			if (i >= children.size())
-				return null;
-			return children.get(i);
-		}
-	}
-
-	/**
-	 * The length of index arrays of jobs within the TreeCache. This assumes
-	 * that all jobs have the same index array length, this is true when the
-	 * cache is used by the iteration strategy but may not be in other
-	 * scenarios, use with caution!
-	 * <p>
-	 * If no jobs have been submitted this method returns -1
-	 */
-	public int getIndexLength() {
-		return this.indexDepth;
-	}
-
-	/**
-	 * Add a job to the cache, the job is inserted at a position corresponding
-	 * to its index array property
-	 * 
-	 * @param j
-	 */
-	public synchronized void insertJob(Job j) {
-		if (root == null)
-			root = new NamedNode();
-		indexDepth = j.getIndex().length;
-		root.insertJob(j);
-	}
-
-	protected synchronized NamedNode nodeAt(int[] position) {
-		if (root == null)
-			return null;
-		NamedNode result = root;
-		int index = 0;
-		while (index < position.length && result != null)
-			result = result.childAt(position[index++]);
-		return result;
-	}
-
-	/**
-	 * Chop the cache off at the specified index
-	 * 
-	 * @param indexArray
-	 */
-	public synchronized void cut(int[] indexArray) {
-		if (indexArray.length > 0) {
-			int[] newIndex = tail(indexArray);
-			NamedNode node = nodeAt(newIndex);
-			if (node != null
-					&& node.children.size() >= indexArray[indexArray.length - 1])
-				node.children.set(indexArray[indexArray.length - 1], null);
-		}
-	}
-
-	/**
-	 * Recursively fetch contents of all nodes under the specified index array,
-	 * used by the prefix matching iteration strategy
-	 */
-	public synchronized List<Job> jobsWithPrefix(int[] prefix) {
-		List<Job> jobs = new ArrayList<>();
-		NamedNode prefixNode = nodeAt(prefix);
-		if (prefixNode != null)
-			getJobsUnder(prefixNode, jobs);
-		return jobs;
-	}
-
-	private synchronized void getJobsUnder(NamedNode node, List<Job> jobs) {
-		if (node.contents != null)
-			jobs.add(node.contents);
-		else
-			for (NamedNode child : node.children)
-				getJobsUnder(child, jobs);
-	}
-
-	/**
-	 * Does the location exist?
-	 * 
-	 * @param location
-	 * @return whether the contents of the location are non null
-	 */
-	public synchronized boolean containsLocation(int[] location) {
-		return (get(location) != null);
-	}
-
-	/**
-	 * Get the job object at the specified index array
-	 * 
-	 * @param location
-	 * @return Job at the specified location or null if no such job was found
-	 */
-	public synchronized Job get(int[] location) {
-		NamedNode n = nodeAt(location);
-		return (n == null ? null : n.contents);
-	}
-
-	/**
-	 * Chop the last index off an int[]
-	 * 
-	 * @param arg
-	 * @return
-	 */
-	private static int[] tail(int[] arg) {
-		int result[] = new int[arg.length - 1];
-		for (int i = 0; i < arg.length - 1; i++)
-			result[i] = arg[i];
-		return result;
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/invocation/WorkflowDataToken.java
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/invocation/WorkflowDataToken.java b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/invocation/WorkflowDataToken.java
deleted file mode 100644
index ca38f0d..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/invocation/WorkflowDataToken.java
+++ /dev/null
@@ -1,91 +0,0 @@
-/*******************************************************************************
- * Copyright (C) 2007 The University of Manchester   
- * 
- *  Modifications to the initial code base are copyright of their
- *  respective authors, or their employers as appropriate.
- * 
- *  This program is free software; you can redistribute it and/or
- *  modify it under the terms of the GNU Lesser General Public License
- *  as published by the Free Software Foundation; either version 2.1 of
- *  the License, or (at your option) any later version.
- *    
- *  This program is distributed in the hope that it will be useful, but
- *  WITHOUT ANY WARRANTY; without even the implied warranty of
- *  MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the GNU
- *  Lesser General Public License for more details.
- *    
- *  You should have received a copy of the GNU Lesser General Public
- *  License along with this program; if not, write to the Free Software
- *  Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307
- ******************************************************************************/
-package net.sf.taverna.t2.invocation;
-
-import net.sf.taverna.t2.reference.T2Reference;
-
-/**
- * A single data token passed between processors in a workflow. This is distinct
- * from the Job in that it contains a single (unnamed) data reference whereas
- * the Job holds a map of arbitrarily many named data references in a bundle.
- * 
- * @author Tom Oinn
- */
-public class WorkflowDataToken extends Event<WorkflowDataToken> {
-	private T2Reference dataRef;
-
-	/**
-	 * Construct a new data token with the specified owning process, conceptual
-	 * index array and data reference
-	 * 
-	 * @param owningProcess
-	 * @param index
-	 * @param dataRef
-	 */
-	public WorkflowDataToken(String owningProcess, int[] index,
-			T2Reference dataRef, InvocationContext context) {
-		super(owningProcess, index, context);
-		this.dataRef = dataRef;
-	}
-
-	@Override
-	public WorkflowDataToken popOwningProcess()
-			throws ProcessIdentifierException {
-		return new WorkflowDataToken(popOwner(), index, dataRef, context);
-	}
-
-	@Override
-	public WorkflowDataToken pushOwningProcess(String localProcessName)
-			throws ProcessIdentifierException {
-		return new WorkflowDataToken(pushOwner(localProcessName), index,
-				dataRef, context);
-	}
-
-	/**
-	 * Return the ID of the data this event represents
-	 * 
-	 * @return
-	 */
-	public T2Reference getData() {
-		return this.dataRef;
-	}
-
-	/**
-	 * Show the owner, index array and data map in textual form for debugging
-	 * and any other purpose. Jobs appear in the form :
-	 * 
-	 * <pre>
-	 * Job(Process1)[2,0]{Input2=dataID4,Input1=dataID3}
-	 * </pre>
-	 */
-	@Override
-	public String toString() {
-		StringBuilder sb = new StringBuilder();
-		sb.append("Token(").append(owner).append(")[");
-		String sep = "";
-		for (int idx : index) {
-			sb.append(sep).append(idx);
-			sep = ",";
-		}
-		sb.append("]{").append(dataRef).append("}");
-		return sb.toString();
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/invocation/package.html
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/invocation/package.html b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/invocation/package.html
deleted file mode 100644
index 8b3c49a..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/invocation/package.html
+++ /dev/null
@@ -1,6 +0,0 @@
-<body>
-Contains classes supporting workflow invocation. Other packages may have
-dependencies on this one but classes here will only be accessed by
-non-taverna code in an invocation context. Nothing in here should be
-critical to the definition and manipulation of the workflow defintion.
-</body>

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/MonitorManager.java
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/MonitorManager.java b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/MonitorManager.java
deleted file mode 100644
index a4e68f4..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/MonitorManager.java
+++ /dev/null
@@ -1,378 +0,0 @@
-/*******************************************************************************
- * Copyright (C) 2007 The University of Manchester   
- * 
- *  Modifications to the initial code base are copyright of their
- *  respective authors, or their employers as appropriate.
- * 
- *  This program is free software; you can redistribute it and/or
- *  modify it under the terms of the GNU Lesser General Public License
- *  as published by the Free Software Foundation; either version 2.1 of
- *  the License, or (at your option) any later version.
- *    
- *  This program is distributed in the hope that it will be useful, but
- *  WITHOUT ANY WARRANTY; without even the implied warranty of
- *  MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the GNU
- *  Lesser General Public License for more details.
- *    
- *  You should have received a copy of the GNU Lesser General Public
- *  License along with this program; if not, write to the Free Software
- *  Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307
- ******************************************************************************/
-package net.sf.taverna.t2.monitor;
-
-import java.util.HashSet;
-import java.util.List;
-import java.util.Set;
-
-import net.sf.taverna.t2.lang.observer.MultiCaster;
-import net.sf.taverna.t2.lang.observer.Observable;
-import net.sf.taverna.t2.lang.observer.Observer;
-import net.sf.taverna.t2.monitor.MonitorManager.MonitorMessage;
-
-/**
- * Manages a list of monitors implementations that get notified to register and
- * deregister nodes (ie. {@link{net.sf.taverna.t2.monitor.MonitorNode}s), in
- * addition to the addition of {@link MonitorableProperty monitorable
- * properties} of such nodes.
- * <p>
- * Nodes are identified by their owning process, which is an array of strings,
- * for instance ["dataflow2", "processor5", "fish"]
- * <p>
- * To notify the (by default 0) monitors, use any of the
- * {@link #addPropertiesToNode(String[], Set)},
- * {@link #registerNode(Object, String[], Set)}, {@link #deregisterNode(String)}
- * methods and variants.
- * <p>
- * To register a monitor, use {@link #addObserver(Observer)}.
- * 
- * @author Stian Soiland-Reyes
- */
-public class MonitorManager implements Observable<MonitorMessage> {
-	private static MonitorManager instance;
-
-	/**
-	 * Get the MonitorManager singleton instance.
-	 * 
-	 * @return The MonitorManager singleton
-	 */
-	public synchronized static MonitorManager getInstance() {
-		if (instance == null)
-			setInstance(new MonitorManager());
-		return instance;
-	}
-
-	/**
-	 * Set the MonitorManager singleton instance. Only to be used by overriding
-	 * super classes at initialisation time.
-	 * 
-	 * @param instance
-	 *            MonitorManager singleton to be returned by
-	 *            {@link #getInstance()}.
-	 */
-	protected synchronized static void setInstance(MonitorManager instance) {
-		MonitorManager.instance = instance;
-	}
-
-	protected MultiCaster<MonitorMessage> multiCaster = new MultiCaster<>(this);
-
-	/**
-	 * Protected constructor, use singleton access
-	 * {@link MonitorManager#getInstance()} instead.
-	 * 
-	 */
-	protected MonitorManager() {
-	}
-
-	/**
-	 * {@inheritDoc}
-	 */
-	@Override
-	public void addObserver(Observer<MonitorMessage> observer) {
-		multiCaster.addObserver(observer);
-	}
-
-	/**
-	 * Push new property get / set methods into the specified node. This is used
-	 * for monitor-able activities where we have to create the node in the state
-	 * tree before we have the set of monitor-able properties for it.
-	 * 
-	 * @param owningProcess
-	 *            the node path to add properties, this must already be
-	 *            registered in the state model, if not then this method fails
-	 *            silently and does nothing.
-	 * @param newProperties
-	 *            the set of properties to add to the specified node in the
-	 *            state model
-	 */
-	public void addPropertiesToNode(String[] owningProcess,
-			Set<MonitorableProperty<?>> newProperties) {
-		multiCaster.notify(new AddPropertiesMessage(owningProcess,
-				newProperties));
-	}
-
-	/**
-	 * Remove the specified node from the monitor. This must be called when the
-	 * final data or completion event leaves a boundary of control. The monitor
-	 * is free to delay the actual removal of state, in which case the node may
-	 * choose to throw exceptions when properties are accessed. The monitor
-	 * should eventually release all references to work-flow objects and process
-	 * identifiers - typically this is used to allow a UI a few seconds delay on
-	 * de-registration so that very fast register / de-register cycles are
-	 * visible to a user.
-	 * <p>
-	 * The specified process identifier must exist within the monitor.
-	 * 
-	 * @param owningProcess
-	 *            the identifier of the node to remove as a :-separated string
-	 */
-	public void deregisterNode(String owningProcessIdentifier) {
-		deregisterNode(owningProcessIdentifier.split(":"));
-	}
-
-	/**
-	 * Remove the specified node from the monitor. This must be called when the
-	 * final data or completion event leaves a boundary of control. The monitor
-	 * is free to delay the actual removal of state, in which case the node may
-	 * choose to throw exceptions when properties are accessed. The monitor
-	 * should eventually release all references to work-flow objects and process
-	 * identifiers - typically this is used to allow a UI a few seconds delay on
-	 * de-registration so that very fast register / de-register cycles are
-	 * visible to a user.
-	 * <p>
-	 * The specified process identifier must exist within the monitor.
-	 * 
-	 * @param owningProcess
-	 *            the identifier of the node to remove.
-	 */
-	public void deregisterNode(String[] owningProcess) {
-		multiCaster.notify(new DeregisterNodeMessage(owningProcess));
-	}
-
-	/**
-	 * {@inheritDoc}
-	 */
-	@Override
-	public List<Observer<MonitorMessage>> getObservers() {
-		return multiCaster.getObservers();
-	}
-
-	/**
-	 * Register a new node with this monitor. New nodes can only be registered
-	 * when a new process identifier is allocated to data corresponding to entry
-	 * to a boundary of control in the data-flow. For cases where extensions
-	 * such as dispatch layers wish to augment existing state the plug-in point
-	 * is responsible for the aggregation of appropriate properties.
-	 * <p>
-	 * The process identifier must not already exist within the state tree, if
-	 * it does it will be ignored. Similarly the parent of the process
-	 * identifier must exist, you cannot specify orphan nodes with no parent.
-	 * 
-	 * @param workflowObject
-	 *            an object within the work-flow model which has received the
-	 *            data stream and caused this node to be created. This may or
-	 *            may not be a top level work-flow entity such as a processor or
-	 *            data-flow. It may be empty in which case null can be used but
-	 *            this is not recommended (there's almost always something you
-	 *            can put here, in general the code to create a new node is
-	 *            contained within something that's just received a data stream
-	 *            so a default approach would be to use the 'this'
-	 *            meta-variable)
-	 * @param owningProcess
-	 *            the :-separated process identifier as a string which has been
-	 *            assigned to data moving through the workflow object. The list
-	 *            of IDs must contain the new identifier as the last element.
-	 */
-	public void registerNode(Object workflowObject,
-			String owningProcessIdentifier) {
-		registerNode(workflowObject, owningProcessIdentifier.split(":"), null);
-	}
-
-	/**
-	 * Register a new node with this monitor. New nodes can only be registered
-	 * when a new process identifier is allocated to data corresponding to entry
-	 * to a boundary of control in the data-flow. For cases where extensions
-	 * such as dispatch layers wish to augment existing state the plug-in point
-	 * is responsible for the aggregation of appropriate properties.
-	 * <p>
-	 * The process identifier must not already exist within the state tree, if
-	 * it does it will be ignored. Similarly the parent of the process
-	 * identifier must exist, you cannot specify orphan nodes with no parent.
-	 * 
-	 * @param workflowObject
-	 *            an object within the work-flow model which has received the
-	 *            data stream and caused this node to be created. This may or
-	 *            may not be a top level work-flow entity such as a processor or
-	 *            data-flow. It may be empty in which case null can be used but
-	 *            this is not recommended (there's almost always something you
-	 *            can put here, in general the code to create a new node is
-	 *            contained within something that's just received a data stream
-	 *            so a default approach would be to use the 'this'
-	 *            meta-variable)
-	 * @param owningProcess
-	 *            the :-separated process identifier as a string which has been
-	 *            assigned to data moving through the workflow object. The list
-	 *            of IDs must contain the new identifier as the last element. *
-	 * @param properties
-	 *            the set of monitor-able, and potentially steer-able,
-	 *            properties which can be monitored from this node. Properties
-	 *            may cache, may become invalid and may make no guarantee about
-	 *            timely updates.
-	 */
-	public void registerNode(Object workflowObject,
-			String owningProcessIdentifier,
-			Set<MonitorableProperty<?>> properties) {
-		registerNode(workflowObject, owningProcessIdentifier.split(":"),
-				properties);
-	}
-
-	/**
-	 * Register a new node with this monitor. New nodes can only be registered
-	 * when a new process identifier is allocated to data corresponding to entry
-	 * to a boundary of control in the data-flow. For cases where extensions
-	 * such as dispatch layers wish to augment existing state the plug-in point
-	 * is responsible for the aggregation of appropriate properties.
-	 * <p>
-	 * The process identifier must not already exist within the state tree, if
-	 * it does it will be ignored. Similarly the parent of the process
-	 * identifier must exist, you cannot specify orphan nodes with no parent.
-	 * 
-	 * @param workflowObject
-	 *            an object within the work-flow model which has received the
-	 *            data stream and caused this node to be created. This may or
-	 *            may not be a top level work-flow entity such as a processor or
-	 *            data-flow. It may be empty in which case null can be used but
-	 *            this is not recommended (there's almost always something you
-	 *            can put here, in general the code to create a new node is
-	 *            contained within something that's just received a data stream
-	 *            so a default approach would be to use the 'this'
-	 *            meta-variable)
-	 * @param owningProcess
-	 *            the process identifier which has been assigned to data moving
-	 *            through the work-flow object. The list of IDs must contain the
-	 *            new identifier as the last element.
-	 */
-	public void registerNode(Object workflowObject, String[] owningProcess) {
-		registerNode(workflowObject, owningProcess, null);
-	}
-
-	/**
-	 * Register a new node with this monitor. New nodes can only be registered
-	 * when a new process identifier is allocated to data corresponding to entry
-	 * to a boundary of control in the data-flow. For cases where extensions
-	 * such as dispatch layers wish to augment existing state the plug-in point
-	 * is responsible for the aggregation of appropriate properties.
-	 * <p>
-	 * The process identifier must not already exist within the state tree, if
-	 * it does it will be ignored. Similarly the parent of the process
-	 * identifier must exist, you cannot specify orphan nodes with no parent.
-	 * 
-	 * @param workflowObject
-	 *            an object within the work-flow model which has received the
-	 *            data stream and caused this node to be created. This may or
-	 *            may not be a top level work-flow entity such as a processor or
-	 *            data-flow. It may be empty in which case null can be used but
-	 *            this is not recommended (there's almost always something you
-	 *            can put here, in general the code to create a new node is
-	 *            contained within something that's just received a data stream
-	 *            so a default approach would be to use the 'this'
-	 *            meta-variable)
-	 * @param owningProcess
-	 *            the process identifier which has been assigned to data moving
-	 *            through the work-flow object. The list of IDs must contain the
-	 *            new identifier as the last element.
-	 * @param properties
-	 *            the set of monitor-able, and potentially steer-able,
-	 *            properties which can be monitored from this node. Properties
-	 *            may cache, may become invalid and may make no guarantee about
-	 *            timely updates.
-	 */
-	public void registerNode(Object workflowObject, String[] owningProcess,
-			Set<MonitorableProperty<?>> properties) {
-		if (properties == null)
-			properties = new HashSet<>();
-		multiCaster.notify(new RegisterNodeMessage(workflowObject,
-				owningProcess, properties));
-	}
-
-	/**
-	 * {@inheritDoc}
-	 */
-	@Override
-	public void removeObserver(Observer<MonitorMessage> observer) {
-		multiCaster.removeObserver(observer);
-	}
-
-	/**
-	 * Message indicating that {@link #getNewProperties() new properties} have
-	 * been added to a node identified by given {@link #getOwningProcess()
-	 * owning process}.
-	 * 
-	 */
-	public class AddPropertiesMessage extends MonitorMessage {
-		private final Set<MonitorableProperty<?>> newProperties;
-
-		public AddPropertiesMessage(String[] owningProcess,
-				Set<MonitorableProperty<?>> newProperties) {
-			super(owningProcess);
-			this.newProperties = newProperties;
-		}
-
-		public Set<MonitorableProperty<?>> getNewProperties() {
-			return newProperties;
-		}
-	}
-
-	/**
-	 * Message indicating that the node of the given {@link #getOwningProcess()
-	 * owning process} is to be deregistered.
-	 * 
-	 */
-	public class DeregisterNodeMessage extends MonitorMessage {
-		public DeregisterNodeMessage(String[] owningProcess) {
-			super(owningProcess);
-		}
-	}
-
-	/**
-	 * Common abstract superclass for all monitor messages. Identifies the
-	 * {@link #getOwningProcess() owning process}.
-	 * 
-	 */
-	public abstract class MonitorMessage {
-		private final String[] owningProcess;
-
-		public MonitorMessage(String[] owningProcess) {
-			this.owningProcess = owningProcess;
-		}
-
-		public String[] getOwningProcess() {
-			return owningProcess;
-		}
-	}
-
-	/**
-	 * Message indicating that the node of the given {@link #getOwningProcess()
-	 * owning process} is to be registered. The node might have
-	 * {@link #getProperties() a set of monitorable properties} and a
-	 * {@link #getWorkflowObject workflow object}.
-	 */
-	public class RegisterNodeMessage extends MonitorMessage {
-		private final Set<MonitorableProperty<?>> properties;
-		private final Object workflowObject;
-
-		public RegisterNodeMessage(Object workflowObject,
-				String[] owningProcess, Set<MonitorableProperty<?>> properties) {
-			super(owningProcess);
-			this.workflowObject = workflowObject;
-			this.properties = properties;
-		}
-
-		public Set<MonitorableProperty<?>> getProperties() {
-			return properties;
-		}
-
-		public Object getWorkflowObject() {
-			return workflowObject;
-		}
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/MonitorNode.java
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/MonitorNode.java b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/MonitorNode.java
deleted file mode 100644
index 371412c..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/MonitorNode.java
+++ /dev/null
@@ -1,76 +0,0 @@
-/*******************************************************************************
- * Copyright (C) 2007 The University of Manchester   
- * 
- *  Modifications to the initial code base are copyright of their
- *  respective authors, or their employers as appropriate.
- * 
- *  This program is free software; you can redistribute it and/or
- *  modify it under the terms of the GNU Lesser General Public License
- *  as published by the Free Software Foundation; either version 2.1 of
- *  the License, or (at your option) any later version.
- *    
- *  This program is distributed in the hope that it will be useful, but
- *  WITHOUT ANY WARRANTY; without even the implied warranty of
- *  MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the GNU
- *  Lesser General Public License for more details.
- *    
- *  You should have received a copy of the GNU Lesser General Public
- *  License along with this program; if not, write to the Free Software
- *  Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307
- ******************************************************************************/
-package net.sf.taverna.t2.monitor;
-
-import java.util.Date;
-import java.util.Set;
-
-/**
- * A single node in the Monitor tree, containing an optional arbitrary workflow
- * object and a set of properties which may or may not be mutable. For tree
- * traversal operations the top level monitor tree must be used, instances of
- * this class are not aware of the surrounding tree structure.
- * 
- * @author Tom Oinn
- */
-public interface MonitorNode {
-	/**
-	 * Each monitor node can reference zero or one workflow object. This is the
-	 * object which is providing any properties the node exposes, so is likely
-	 * to be a workflow or processor but could be anything.
-	 * 
-	 * @return the workflow object providing this node's properties, or null if
-	 *         there is no directly corresponding workflow object. Note that
-	 *         this workflow object can be anything, and may not be a top level
-	 *         workflow object at all.
-	 */
-	Object getWorkflowObject();
-
-	/**
-	 * Each monitor node has an identity corresponding to the identifier stack
-	 * of the data flowing through the workflow object that created it. This
-	 * string array also defines its position in the monitor tree.
-	 */
-	String[] getOwningProcess();
-
-	/**
-	 * Each monitor node exposes a set of properties, which may or may not be
-	 * mutable
-	 */
-	Set<? extends MonitorableProperty<?>> getProperties();
-
-	/**
-	 * Each node has a creation date
-	 */
-	Date getCreationDate();
-
-	/**
-	 * Properties can be added to the monitor node after creation if required,
-	 * although this should be used only when necessary to avoid race conditions
-	 */
-	void addMonitorableProperty(MonitorableProperty<?> newProperty);
-
-	/**
-	 * Nodes can persist in the tree after they have expired, in which case this
-	 * will return true.
-	 */
-	boolean hasExpired();
-}

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/MonitorableProperty.java
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/MonitorableProperty.java b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/MonitorableProperty.java
deleted file mode 100644
index 1f55811..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/MonitorableProperty.java
+++ /dev/null
@@ -1,55 +0,0 @@
-/*******************************************************************************
- * Copyright (C) 2007 The University of Manchester   
- * 
- *  Modifications to the initial code base are copyright of their
- *  respective authors, or their employers as appropriate.
- * 
- *  This program is free software; you can redistribute it and/or
- *  modify it under the terms of the GNU Lesser General Public License
- *  as published by the Free Software Foundation; either version 2.1 of
- *  the License, or (at your option) any later version.
- *    
- *  This program is distributed in the hope that it will be useful, but
- *  WITHOUT ANY WARRANTY; without even the implied warranty of
- *  MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the GNU
- *  Lesser General Public License for more details.
- *    
- *  You should have received a copy of the GNU Lesser General Public
- *  License along with this program; if not, write to the Free Software
- *  Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307
- ******************************************************************************/
-package net.sf.taverna.t2.monitor;
-
-import java.util.Date;
-
-/**
- * A single readable property contained by a Monitorable. This is used to
- * express properties that are dynamic with respect to workflow invocation as
- * opposed to static properties defined by the workflow model. A typical example
- * of this might be dispatch stack queue size or number of jobs completed. All
- * properties are defined relative to a particular owning process identifier,
- * this is the same mechanism as used in the workflow model to isolate different
- * data streams.
- * 
- * @author Tom Oinn
- */
-public interface MonitorableProperty<T> {
-	/**
-	 * Return the value of this property
-	 */
-	T getValue() throws NoSuchPropertyException;
-
-	/**
-	 * Return the name of this property, names are heirarchical in nature and
-	 * are defined as an array of String objects. This is to allow e.g. dispatch
-	 * layers to expose a set of related properties under the same root name.
-	 */
-	String[] getName();
-
-	/**
-	 * Get the last update date for this property, if the property is immutable
-	 * then this should be set to the date at which the implementation is
-	 * created.
-	 */
-	Date getLastModified();
-}

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/NoSuchPropertyException.java
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/NoSuchPropertyException.java b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/NoSuchPropertyException.java
deleted file mode 100644
index edb4751..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/NoSuchPropertyException.java
+++ /dev/null
@@ -1,50 +0,0 @@
-/*******************************************************************************
- * Copyright (C) 2007 The University of Manchester   
- * 
- *  Modifications to the initial code base are copyright of their
- *  respective authors, or their employers as appropriate.
- * 
- *  This program is free software; you can redistribute it and/or
- *  modify it under the terms of the GNU Lesser General Public License
- *  as published by the Free Software Foundation; either version 2.1 of
- *  the License, or (at your option) any later version.
- *    
- *  This program is distributed in the hope that it will be useful, but
- *  WITHOUT ANY WARRANTY; without even the implied warranty of
- *  MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the GNU
- *  Lesser General Public License for more details.
- *    
- *  You should have received a copy of the GNU Lesser General Public
- *  License along with this program; if not, write to the Free Software
- *  Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307
- ******************************************************************************/
-package net.sf.taverna.t2.monitor;
-
-/**
- * Thrown when an attempt is made to access a monitorable property which is no
- * longer current. This is quite a common event as the properties can change
- * extremely quickly whereas the logic accessing them is expected not to.
- * Consumers of state data must cope with this disparity by handling this
- * exception where it is thrown.
- * 
- * @author Tom Oinn
- */
-public class NoSuchPropertyException extends Exception {
-	private static final long serialVersionUID = 6320919057517500603L;
-
-	public NoSuchPropertyException() {
-		super();
-	}
-
-	public NoSuchPropertyException(String arg0, Throwable arg1) {
-		super(arg0, arg1);
-	}
-
-	public NoSuchPropertyException(String arg0) {
-		super(arg0);
-	}
-
-	public NoSuchPropertyException(Throwable arg0) {
-		super(arg0);
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/SteerableProperty.java
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/SteerableProperty.java b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/SteerableProperty.java
deleted file mode 100644
index 44301cc..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/SteerableProperty.java
+++ /dev/null
@@ -1,37 +0,0 @@
-/*******************************************************************************
- * Copyright (C) 2007 The University of Manchester   
- * 
- *  Modifications to the initial code base are copyright of their
- *  respective authors, or their employers as appropriate.
- * 
- *  This program is free software; you can redistribute it and/or
- *  modify it under the terms of the GNU Lesser General Public License
- *  as published by the Free Software Foundation; either version 2.1 of
- *  the License, or (at your option) any later version.
- *    
- *  This program is distributed in the hope that it will be useful, but
- *  WITHOUT ANY WARRANTY; without even the implied warranty of
- *  MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the GNU
- *  Lesser General Public License for more details.
- *    
- *  You should have received a copy of the GNU Lesser General Public
- *  License along with this program; if not, write to the Free Software
- *  Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307
- ******************************************************************************/
-package net.sf.taverna.t2.monitor;
-
-/**
- * Some monitorable properties are mutable and can be written to by steering
- * agents or other clients.
- * 
- * @author Tom Oinn
- */
-public interface SteerableProperty<T> extends MonitorableProperty<T> {
-	/**
-	 * Set the property value
-	 * 
-	 * @param newValue
-	 * @throws NoSuchPropertyException
-	 */
-	void setProperty(T newValue) throws NoSuchPropertyException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/package.html
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/package.html b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/package.html
deleted file mode 100644
index 17ee572..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/monitor/package.html
+++ /dev/null
@@ -1,36 +0,0 @@
-<body>
-Defines the API for the monitoring and steering system. As data flows
-through a workflow it passes through a succession of bounds of control.
-Each of these boundaries corresponds to a workflow, a nested process or
-some other contained entity where a new owning process identifier is
-pushed onto the process identifier stack for that data item. This
-modification to the owning process identifier implicitly creates a tree
-structure where the parent of a particular identifier can be obtained by
-popping the last component off its identifier stack (in general this
-means splitting into a list by the ':' character and removing the last
-item).
-<p>Any entity issuing a new identifier to data in this way must
-implement the Monitorable interface and should register itself with the
-Monitor before or at the point of assigning this new identifier. Some
-cases may register child items rather than delegating to the children
-themselves, for example a workflow definition may register all its
-processors as children and deregister on workflow completion rather than
-the process happening for each processor but however it is accomplished
-the result is the creation within the Monitor of a tree where nodes
-contain references to Monitorable objects within the workflow
-definition.
-<p>The Monitorable interface defines a simple contract - once
-registered the implementing class can return a list of
-MonitorableProperty instances defining the exposed dynamic state at this
-node in the context of a given process identifier. Any of these
-properties may be mutable in which case they will extend
-SteerableProperty, a sub-interface of MonitorableProperty which allows
-for the mutation of the property.
-<p>By design the Monitor is rather powerful - it has the ability to
-modify steerable properties in any running workflow. It is obviously
-desirable to restrict this, passing any given monitoring or steering
-agent a restricted subset of the monitor tree rooted at a specific
-process identifier and preventing direct access to the Monitor class.
-The Monitor interface defines methods to expose subsets of the
-monitorable state for this reason.
-</body>

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/AbstractProvenanceItem.java
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/AbstractProvenanceItem.java b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/AbstractProvenanceItem.java
deleted file mode 100644
index b212e73..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/AbstractProvenanceItem.java
+++ /dev/null
@@ -1,77 +0,0 @@
-package net.sf.taverna.t2.provenance.item;
-
-import net.sf.taverna.t2.provenance.vocabulary.SharedVocabulary;
-
-public abstract class AbstractProvenanceItem implements ProvenanceItem {
-	@Override
-	public abstract SharedVocabulary getEventType();
-
-	private String identifier, parentId, processId, workflowId;
-
-	@Override
-	public final String getIdentifier() {
-		return identifier;
-	}
-
-	@Override
-	public int hashCode() {
-		return 31 + (identifier == null ? 0 : identifier.hashCode());
-	}
-
-	@Override
-	public boolean equals(Object obj) {
-		if (this == obj)
-			return true;
-		if (obj == null)
-			return false;
-		if (getClass() != obj.getClass())
-			return false;
-		AbstractProvenanceItem other = (AbstractProvenanceItem) obj;
-		if (identifier == null) {
-			if (other.identifier != null)
-				return false;
-		} else if (!identifier.equals(other.identifier))
-			return false;
-		return true;
-	}
-
-	@Override
-	public final void setIdentifier(String identifier) {
-		this.identifier = identifier;
-	}
-
-	@Override
-	public final String getParentId() {
-		return parentId;
-	}
-
-	@Override
-	public final void setParentId(String parentId) {
-		this.parentId = parentId;
-	}
-
-	@Override
-	public final String getProcessId() {
-		return processId;
-	}
-
-	@Override
-	public final void setProcessId(String processId) {
-		this.processId = processId;
-	}
-
-	@Override
-	public final String getWorkflowId() {
-		return workflowId;
-	}
-
-	@Override
-	public final void setWorkflowId(String workflowId) {
-		this.workflowId = workflowId;
-	}
-	
-	@Override
-	public String toString() {
-		return getEventType() + " id:" + getIdentifier() + " parent:" + getParentId();
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/ActivityProvenanceItem.java
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/ActivityProvenanceItem.java b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/ActivityProvenanceItem.java
deleted file mode 100644
index d9bda73..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/ActivityProvenanceItem.java
+++ /dev/null
@@ -1,62 +0,0 @@
-/*******************************************************************************
- * Copyright (C) 2007 The University of Manchester   
- * 
- *  Modifications to the initial code base are copyright of their
- *  respective authors, or their employers as appropriate.
- * 
- *  This program is free software; you can redistribute it and/or
- *  modify it under the terms of the GNU Lesser General Public License
- *  as published by the Free Software Foundation; either version 2.1 of
- *  the License, or (at your option) any later version.
- *    
- *  This program is distributed in the hope that it will be useful, but
- *  WITHOUT ANY WARRANTY; without even the implied warranty of
- *  MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the GNU
- *  Lesser General Public License for more details.
- *    
- *  You should have received a copy of the GNU Lesser General Public
- *  License along with this program; if not, write to the Free Software
- *  Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307
- ******************************************************************************/
-package net.sf.taverna.t2.provenance.item;
-
-import net.sf.taverna.t2.provenance.vocabulary.SharedVocabulary;
-import net.sf.taverna.t2.workflowmodel.processor.activity.Activity;
-
-/**
- * Contains details for an enacted Activity. Parent is a
- * {@link ProcessorProvenanceItem}. Children are {@link IterationProvenanceItem}
- * s. There could be multiple {@link ActivityProvenanceItem}s for each
- * {@link ProcessorProvenanceItem}
- * 
- * @author Ian Dunlop
- * @author Stuart Owen
- * @author Paolo Missier
- */
-public class ActivityProvenanceItem extends AbstractProvenanceItem implements ProvenanceItem  {
-	private Activity<?> activity;
-	private IterationProvenanceItem iterationProvenanceItem;
-	
-	public void setIterationProvenanceItem(
-			IterationProvenanceItem iterationProvenanceItem) {
-		this.iterationProvenanceItem = iterationProvenanceItem;
-	}
-
-	public IterationProvenanceItem getIterationProvenanceItem() {
-		return iterationProvenanceItem;
-	}
-
-	@Override
-	public SharedVocabulary getEventType() {
-		return SharedVocabulary.ACTIVITY_EVENT_TYPE;
-	}
-
-	public Activity<?> getActivity() {
-		return activity;
-	}
-
-	public void setActivity(Activity<?> activity) {
-		this.activity = activity;
-	}
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/DataProvenanceItem.java
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/DataProvenanceItem.java b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/DataProvenanceItem.java
deleted file mode 100644
index 59dc3fe..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/DataProvenanceItem.java
+++ /dev/null
@@ -1,63 +0,0 @@
-/*******************************************************************************
- * Copyright (C) 2007 The University of Manchester   
- * 
- *  Modifications to the initial code base are copyright of their
- *  respective authors, or their employers as appropriate.
- * 
- *  This program is free software; you can redistribute it and/or
- *  modify it under the terms of the GNU Lesser General Public License
- *  as published by the Free Software Foundation; either version 2.1 of
- *  the License, or (at your option) any later version.
- *    
- *  This program is distributed in the hope that it will be useful, but
- *  WITHOUT ANY WARRANTY; without even the implied warranty of
- *  MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the GNU
- *  Lesser General Public License for more details.
- *    
- *  You should have received a copy of the GNU Lesser General Public
- *  License along with this program; if not, write to the Free Software
- *  Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307
- ******************************************************************************/
-package net.sf.taverna.t2.provenance.item;
-
-import java.util.Map;
-
-import net.sf.taverna.t2.reference.ReferenceService;
-import net.sf.taverna.t2.reference.T2Reference;
-
-/**
- * Contains references to data which a workflow has used or created. Parent is
- * an {@link IterationProvenanceItem}
- * 
- * @author Ian Dunlop
- * @auhor Stuart Owen
- * @author Paolo Missier
- */
-public abstract class DataProvenanceItem extends AbstractProvenanceItem {
-	/** A map of port name to data reference */
-	private Map<String, T2Reference> dataMap;
-	private ReferenceService referenceService;
-
-	/**
-	 * Is this {@link ProvenanceItem} for input or output data
-	 * 
-	 * @return
-	 */
-	protected abstract boolean isInput();
-
-	public Map<String, T2Reference> getDataMap() {
-		return dataMap;
-	}
-
-	public void setDataMap(Map<String, T2Reference> dataMap) {
-		this.dataMap = dataMap;
-	}
-	
-	public void setReferenceService(ReferenceService referenceService) {
-		this.referenceService = referenceService;
-	}
-
-	public ReferenceService getReferenceService() {
-		return referenceService;
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/DataflowRunComplete.java
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/DataflowRunComplete.java b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/DataflowRunComplete.java
deleted file mode 100644
index d830efb..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/DataflowRunComplete.java
+++ /dev/null
@@ -1,61 +0,0 @@
-/*******************************************************************************
- * Copyright (C) 2007 The University of Manchester   
- * 
- *  Modifications to the initial code base are copyright of their
- *  respective authors, or their employers as appropriate.
- * 
- *  This program is free software; you can redistribute it and/or
- *  modify it under the terms of the GNU Lesser General Public License
- *  as published by the Free Software Foundation; either version 2.1 of
- *  the License, or (at your option) any later version.
- *    
- *  This program is distributed in the hope that it will be useful, but
- *  WITHOUT ANY WARRANTY; without even the implied warranty of
- *  MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the GNU
- *  Lesser General Public License for more details.
- *    
- *  You should have received a copy of the GNU Lesser General Public
- *  License along with this program; if not, write to the Free Software
- *  Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307
- ******************************************************************************/
-package net.sf.taverna.t2.provenance.item;
-
-import java.sql.Timestamp;
-
-import net.sf.taverna.t2.facade.WorkflowInstanceFacade.State;
-import net.sf.taverna.t2.provenance.vocabulary.SharedVocabulary;
-
-/**
- * Informs the {@link ProvenanceConnector} that a workflow has been run to
- * completion. If a {@link ProvenanceConnector} receives this event then it
- * means that there are no further events to come and that the workflow has been
- * enacted to completion
- * 
- * @author Ian Dunlop
- */
-public class DataflowRunComplete extends AbstractProvenanceItem {
-	private SharedVocabulary eventType = SharedVocabulary.END_WORKFLOW_EVENT_TYPE;
-	private Timestamp invocationEnded;
-	private State state;
-
-	public Timestamp getInvocationEnded() {
-		return invocationEnded;
-	}
-
-	@Override
-	public SharedVocabulary getEventType() {
-		return eventType;
-	}
-
-	public void setInvocationEnded(Timestamp invocationEnded) {
-		this.invocationEnded = invocationEnded;
-	}
-
-	public void setState(State state) {
-		this.state = state;
-	}
-
-	public State getState() {
-		return state;
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/ErrorProvenanceItem.java
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/ErrorProvenanceItem.java b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/ErrorProvenanceItem.java
deleted file mode 100644
index 6929f55..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/ErrorProvenanceItem.java
+++ /dev/null
@@ -1,71 +0,0 @@
-/*******************************************************************************
- * Copyright (C) 2007 The University of Manchester   
- * 
- *  Modifications to the initial code base are copyright of their
- *  respective authors, or their employers as appropriate.
- * 
- *  This program is free software; you can redistribute it and/or
- *  modify it under the terms of the GNU Lesser General Public License
- *  as published by the Free Software Foundation; either version 2.1 of
- *  the License, or (at your option) any later version.
- *    
- *  This program is distributed in the hope that it will be useful, but
- *  WITHOUT ANY WARRANTY; without even the implied warranty of
- *  MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the GNU
- *  Lesser General Public License for more details.
- *    
- *  You should have received a copy of the GNU Lesser General Public
- *  License along with this program; if not, write to the Free Software
- *  Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307
- ******************************************************************************/
-package net.sf.taverna.t2.provenance.item;
-
-import net.sf.taverna.t2.provenance.vocabulary.SharedVocabulary;
-
-/**
- * When an error is received in the dispatch stack, one of these is created and
- * sent across to the {@link ProvenanceConnector}. Parent is an
- * {@link IterationProvenanceItem}
- * 
- * @author Ian Dunlop
- * @author Stuart Owen
- * @author Paolo Missier
- */
-public class ErrorProvenanceItem extends AbstractProvenanceItem {
-	private Throwable cause;
-	private String message;
-	private String errorType;
-	private SharedVocabulary eventType = SharedVocabulary.ERROR_EVENT_TYPE;
-
-	public ErrorProvenanceItem() {
-	}
-
-	@Override
-	public SharedVocabulary getEventType() {
-		return eventType;
-	}
-
-	public Throwable getCause() {
-		return cause;
-	}
-
-	public void setCause(Throwable cause) {
-		this.cause = cause;
-	}
-
-	public String getMessage() {
-		return message;
-	}
-
-	public void setMessage(String message) {
-		this.message = message;
-	}
-
-	public String getErrorType() {
-		return errorType;
-	}
-
-	public void setErrorType(String errorType) {
-		this.errorType = errorType;
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/InputDataProvenanceItem.java
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/InputDataProvenanceItem.java b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/InputDataProvenanceItem.java
deleted file mode 100644
index 238a686..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/InputDataProvenanceItem.java
+++ /dev/null
@@ -1,49 +0,0 @@
-/*******************************************************************************
- * Copyright (C) 2007 The University of Manchester   
- * 
- *  Modifications to the initial code base are copyright of their
- *  respective authors, or their employers as appropriate.
- * 
- *  This program is free software; you can redistribute it and/or
- *  modify it under the terms of the GNU Lesser General Public License
- *  as published by the Free Software Foundation; either version 2.1 of
- *  the License, or (at your option) any later version.
- *    
- *  This program is distributed in the hope that it will be useful, but
- *  WITHOUT ANY WARRANTY; without even the implied warranty of
- *  MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the GNU
- *  Lesser General Public License for more details.
- *    
- *  You should have received a copy of the GNU Lesser General Public
- *  License along with this program; if not, write to the Free Software
- *  Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307
- ******************************************************************************/
-package net.sf.taverna.t2.provenance.item;
-
-import net.sf.taverna.t2.provenance.vocabulary.SharedVocabulary;
-
-/**
- * Contains details of port names and the input data they receive. Parent is an
- * {@link IterationProvenanceItem}
- * 
- * @author Paolo Missier
- * @author Stuart Owen
- * @author Ian Dunlop
- */
-public class InputDataProvenanceItem extends DataProvenanceItem {
-	private SharedVocabulary eventType = SharedVocabulary.INPUTDATA_EVENT_TYPE;
-
-	/**
-	 * Used when generating the xml version by the {@link DataProvenanceItem}.
-	 * Identifies this {@link DataProvenanceItem} as containing input
-	 */
-	@Override
-	protected boolean isInput() {
-		return true;
-	}
-
-	@Override
-	public SharedVocabulary getEventType() {
-		return eventType;
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/InvocationStartedProvenanceItem.java
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/InvocationStartedProvenanceItem.java b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/InvocationStartedProvenanceItem.java
deleted file mode 100644
index 6c9228a..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/InvocationStartedProvenanceItem.java
+++ /dev/null
@@ -1,41 +0,0 @@
-package net.sf.taverna.t2.provenance.item;
-
-import java.sql.Date;
-
-import net.sf.taverna.t2.provenance.vocabulary.SharedVocabulary;
-import net.sf.taverna.t2.workflowmodel.processor.activity.Activity;
-
-public class InvocationStartedProvenanceItem extends AbstractProvenanceItem {
-	private Activity<?> activity;
-	private String invocationProcessId;
-	private Date invocationStarted;
-
-	public final Date getInvocationStarted() {
-		return invocationStarted;
-	}
-
-	@Override
-	public SharedVocabulary getEventType() {
-		return SharedVocabulary.INVOCATION_STARTED_EVENT_TYPE;
-	}
-
-	public void setActivity(Activity<?> activity) {
-		this.activity = activity;
-	}
-
-	public Activity<?> getActivity() {
-		return activity;
-	}
-
-	public void setInvocationProcessId(String invocationProcessId) {
-		this.invocationProcessId = invocationProcessId;
-	}
-
-	public String getInvocationProcessId() {
-		return invocationProcessId;
-	}
-
-	public void setInvocationStarted(Date invocationStarted) {
-		this.invocationStarted = invocationStarted;
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/IterationProvenanceItem.java
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/IterationProvenanceItem.java b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/IterationProvenanceItem.java
deleted file mode 100644
index b567d1c..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/IterationProvenanceItem.java
+++ /dev/null
@@ -1,108 +0,0 @@
-/*******************************************************************************
- * Copyright (C) 2007 The University of Manchester   
- * 
- *  Modifications to the initial code base are copyright of their
- *  respective authors, or their employers as appropriate.
- * 
- *  This program is free software; you can redistribute it and/or
- *  modify it under the terms of the GNU Lesser General Public License
- *  as published by the Free Software Foundation; either version 2.1 of
- *  the License, or (at your option) any later version.
- *    
- *  This program is distributed in the hope that it will be useful, but
- *  WITHOUT ANY WARRANTY; without even the implied warranty of
- *  MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the GNU
- *  Lesser General Public License for more details.
- *    
- *  You should have received a copy of the GNU Lesser General Public
- *  License along with this program; if not, write to the Free Software
- *  Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307
- ******************************************************************************/
-package net.sf.taverna.t2.provenance.item;
-
-import java.sql.Timestamp;
-
-import net.sf.taverna.t2.provenance.vocabulary.SharedVocabulary;
-
-/**
- * One of these is created for each iteration inside an enacted activity.
- * Contains both the input and output data and port names contained inside
- * {@link DataProvenanceItem}s. The actual iteration number is contained inside
- * an int array eg [1]
- * 
- * @author Ian Dunlop
- * @author Paolo Missier
- * @author Stuart Owen
- */
-public class IterationProvenanceItem extends AbstractProvenanceItem {
-	private Timestamp enactmentEnded;
-	private Timestamp enactmentStarted;
-	private ErrorProvenanceItem errorItem;
-	private final SharedVocabulary eventType = SharedVocabulary.ITERATION_EVENT_TYPE;
-	private InputDataProvenanceItem inputDataItem;
-	private int[] iteration;
-	private OutputDataProvenanceItem outputDataItem;
-	private IterationProvenanceItem parentIterationItem = null;
-
-	public IterationProvenanceItem getParentIterationItem() {
-		return parentIterationItem;
-	}
-
-	public Timestamp getEnactmentEnded() {
-		return enactmentEnded;
-	}
-
-	public Timestamp getEnactmentStarted() {
-		return enactmentStarted;
-	}
-
-	public ErrorProvenanceItem getErrorItem() {
-		return errorItem;
-	}
-
-	@Override
-	public SharedVocabulary getEventType() {
-		return eventType;
-	}
-
-	public InputDataProvenanceItem getInputDataItem() {
-		return inputDataItem;
-	}
-
-	public int[] getIteration() {
-		return iteration;
-	}
-
-	public OutputDataProvenanceItem getOutputDataItem() {
-		return outputDataItem;
-	}
-
-	public void setEnactmentEnded(Timestamp enactmentEnded) {
-		this.enactmentEnded = enactmentEnded;
-	}
-
-	public void setEnactmentStarted(Timestamp enactmentStarted) {
-		this.enactmentStarted = enactmentStarted;
-	}
-
-	public void setErrorItem(ErrorProvenanceItem errorItem) {
-		this.errorItem = errorItem;
-	}
-
-	public void setInputDataItem(InputDataProvenanceItem inputDataItem) {
-		this.inputDataItem = inputDataItem;
-	}
-
-	public void setIteration(int[] iteration) {
-		this.iteration = iteration;
-	}
-
-	public void setOutputDataItem(OutputDataProvenanceItem outputDataItem) {
-		this.outputDataItem = outputDataItem;
-	}
-
-	public void setParentIterationItem(
-			IterationProvenanceItem parentIterationItem) {
-		this.parentIterationItem = parentIterationItem;
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/OutputDataProvenanceItem.java
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/OutputDataProvenanceItem.java b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/OutputDataProvenanceItem.java
deleted file mode 100644
index de8e424..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/OutputDataProvenanceItem.java
+++ /dev/null
@@ -1,49 +0,0 @@
-/*******************************************************************************
- * Copyright (C) 2007 The University of Manchester   
- * 
- *  Modifications to the initial code base are copyright of their
- *  respective authors, or their employers as appropriate.
- * 
- *  This program is free software; you can redistribute it and/or
- *  modify it under the terms of the GNU Lesser General Public License
- *  as published by the Free Software Foundation; either version 2.1 of
- *  the License, or (at your option) any later version.
- *    
- *  This program is distributed in the hope that it will be useful, but
- *  WITHOUT ANY WARRANTY; without even the implied warranty of
- *  MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the GNU
- *  Lesser General Public License for more details.
- *    
- *  You should have received a copy of the GNU Lesser General Public
- *  License along with this program; if not, write to the Free Software
- *  Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307
- ******************************************************************************/
-package net.sf.taverna.t2.provenance.item;
-
-import net.sf.taverna.t2.provenance.vocabulary.SharedVocabulary;
-
-/**
- * Contains details of port names and the output data they receive. Parent is an
- * {@link IterationProvenanceItem}
- * 
- * @author Paolo Missier
- * @author Stuart Owen
- * @author Ian Dunlop
- */
-public class OutputDataProvenanceItem extends DataProvenanceItem {
-	private SharedVocabulary eventType = SharedVocabulary.OUTPUTDATA_EVENT_TYPE;
-
-	/**
-	 * Used when generating the xml version by the {@link DataProvenanceItem}.
-	 * Identifies this {@link DataProvenanceItem} as containing output
-	 */
-	@Override
-	protected boolean isInput() {
-		return false;
-	}
-
-	@Override
-	public SharedVocabulary getEventType() {
-		return eventType;
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/ProcessProvenanceItem.java
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/ProcessProvenanceItem.java b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/ProcessProvenanceItem.java
deleted file mode 100644
index 06cb76e..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/ProcessProvenanceItem.java
+++ /dev/null
@@ -1,89 +0,0 @@
-/*******************************************************************************
- * Copyright (C) 2007 The University of Manchester   
- * 
- *  Modifications to the initial code base are copyright of their
- *  respective authors, or their employers as appropriate.
- * 
- *  This program is free software; you can redistribute it and/or
- *  modify it under the terms of the GNU Lesser General Public License
- *  as published by the Free Software Foundation; either version 2.1 of
- *  the License, or (at your option) any later version.
- *    
- *  This program is distributed in the hope that it will be useful, but
- *  WITHOUT ANY WARRANTY; without even the implied warranty of
- *  MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the GNU
- *  Lesser General Public License for more details.
- *    
- *  You should have received a copy of the GNU Lesser General Public
- *  License along with this program; if not, write to the Free Software
- *  Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307
- ******************************************************************************/
-package net.sf.taverna.t2.provenance.item;
-
-import net.sf.taverna.t2.provenance.vocabulary.SharedVocabulary;
-
-/**
- * Each time a job is received by the dispatch stack one of these will be
- * created. It has a {@link ProcessorProvenanceItem} as its child. Its parent is
- * a {@link WorkflowProvenanceItem} which in turn knows the unique id of the
- * workflow the provenance is being stored for. NOTE: May be superfluous since
- * it essentially mimics the behaviour of its child item but may be more hastle
- * than it is worth to remove it
- * 
- * @author Stuart owen
- * @author Paolo Missier
- * @author Ian Dunlop
- */
-public class ProcessProvenanceItem extends AbstractProvenanceItem {
-	private String owningProcess;
-	private ProcessorProvenanceItem processorProvenanceItem;
-	private String facadeID;
-	private String dataflowID;
-	private SharedVocabulary eventType = SharedVocabulary.PROCESS_EVENT_TYPE;
-
-	/**
-	 * As {@link WorkflowInstanceFacade}s are created for a Processor the
-	 * details are appended to the owning process identifier. This is in the
-	 * form facadeX:dataflowY:ProcessorZ etc. This method returns the facadeX
-	 * part.
-	 * 
-	 * @return
-	 */
-	public String getFacadeID() {
-		return facadeID;
-	}
-
-	public void setProcessorProvenanceItem(
-			ProcessorProvenanceItem processorProvenanceItem) {
-		this.processorProvenanceItem = processorProvenanceItem;
-	}
-
-	public ProcessorProvenanceItem getProcessorProvenanceItem() {
-		return processorProvenanceItem;
-	}
-
-	@Override
-	public SharedVocabulary getEventType() {
-		return eventType;
-	}
-
-	public String getOwningProcess() {
-		return owningProcess;
-	}
-
-	public void setOwningProcess(String owningProcess) {
-		this.owningProcess = owningProcess;
-	}
-
-	public void setFacadeID(String facadeID) {
-		this.facadeID = facadeID;
-	}
-
-	public void setDataflowID(String dataflowID) {
-		this.dataflowID = dataflowID;
-	}
-
-	public String getDataflowID() {
-		return dataflowID;
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/ProcessorProvenanceItem.java
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/ProcessorProvenanceItem.java b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/ProcessorProvenanceItem.java
deleted file mode 100644
index c82750c..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/ProcessorProvenanceItem.java
+++ /dev/null
@@ -1,57 +0,0 @@
-/*******************************************************************************
- * Copyright (C) 2007 The University of Manchester   
- * 
- *  Modifications to the initial code base are copyright of their
- *  respective authors, or their employers as appropriate.
- * 
- *  This program is free software; you can redistribute it and/or
- *  modify it under the terms of the GNU Lesser General Public License
- *  as published by the Free Software Foundation; either version 2.1 of
- *  the License, or (at your option) any later version.
- *    
- *  This program is distributed in the hope that it will be useful, but
- *  WITHOUT ANY WARRANTY; without even the implied warranty of
- *  MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the GNU
- *  Lesser General Public License for more details.
- *    
- *  You should have received a copy of the GNU Lesser General Public
- *  License along with this program; if not, write to the Free Software
- *  Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307
- ******************************************************************************/
-package net.sf.taverna.t2.provenance.item;
-
-import net.sf.taverna.t2.provenance.vocabulary.SharedVocabulary;
-
-/**
- * Each Processor inside a workflow will have one of these for each provenance
- * run. Its parent is a {@link ProcessProvenanceItem} and child is an
- * {@link ActivityProvenanceItem}. In theory there could be more than one
- * {@link ActivityProvenanceItem} per processor to cope with failover etc
- * 
- * @author Ian Dunlop
- * @author Stuart Owen
- * @author Paolo Missier
- */
-public class ProcessorProvenanceItem extends AbstractProvenanceItem {
-	private ActivityProvenanceItem activityProvenanceItem;
-	private String identifier;
-	private SharedVocabulary eventType = SharedVocabulary.PROCESSOR_EVENT_TYPE;
-
-	public void setActivityProvenanceItem(
-			ActivityProvenanceItem activityProvenanceItem) {
-		this.activityProvenanceItem = activityProvenanceItem;
-	}
-
-	public ActivityProvenanceItem getActivityProvenanceItem() {
-		return activityProvenanceItem;
-	}
-
-	public String getProcessorID() {
-		return identifier;
-	}
-
-	@Override
-	public SharedVocabulary getEventType() {
-		return eventType;
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/ProvenanceItem.java
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/ProvenanceItem.java b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/ProvenanceItem.java
deleted file mode 100644
index 97fdc04..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/ProvenanceItem.java
+++ /dev/null
@@ -1,103 +0,0 @@
-/*******************************************************************************
- * Copyright (C) 2007 The University of Manchester   
- * 
- *  Modifications to the initial code base are copyright of their
- *  respective authors, or their employers as appropriate.
- * 
- *  This program is free software; you can redistribute it and/or
- *  modify it under the terms of the GNU Lesser General Public License
- *  as published by the Free Software Foundation; either version 2.1 of
- *  the License, or (at your option) any later version.
- *    
- *  This program is distributed in the hope that it will be useful, but
- *  WITHOUT ANY WARRANTY; without even the implied warranty of
- *  MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the GNU
- *  Lesser General Public License for more details.
- *    
- *  You should have received a copy of the GNU Lesser General Public
- *  License along with this program; if not, write to the Free Software
- *  Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307
- ******************************************************************************/
-package net.sf.taverna.t2.provenance.item;
-
-import net.sf.taverna.t2.provenance.vocabulary.SharedVocabulary;
-
-/**
- * Used to store some enactment information during a workflow run
- * 
- * @see AbstractProvenanceItem
- * @author Ian Dunlop
- */
-public interface ProvenanceItem {
-	/**
-	 * What type of information does the item contain. The
-	 * {@link SharedVocabulary} can be used to identify it
-	 * 
-	 * @return
-	 */
-	SharedVocabulary getEventType();
-
-	/**
-	 * The unique identifier for this item
-	 * 
-	 * @return
-	 */
-	String getIdentifier();
-
-	/**
-	 * A unique id for this event. Any children would use this as their parentId
-	 * 
-	 * @param identifier
-	 */
-	void setIdentifier(String identifier);
-
-	/**
-	 * The workflow model id that is supplied during enactment eg
-	 * facade0:dataflow2:processor1
-	 * 
-	 * @param processId
-	 */
-	void setProcessId(String processId);
-
-	/**
-	 * Get the enactor supplie identifier
-	 * 
-	 * @return
-	 */
-	String getProcessId();
-
-	/**
-	 * The parent of this provenance Item. The model is
-	 * WorkflowProvenanceItem>ProcessProvenanceItem
-	 * >ProcessorProvenanceItem>ActivityProvenanceITem
-	 * >IterationProvenanceItem>DataProvenanceItem
-	 * 
-	 * Additionally there is a WorkflowDataProvenanceItem that is sent when the
-	 * facade receives a completion event and a ErrorProvenanceItem when things
-	 * go wrong
-	 * 
-	 * @param parentId
-	 */
-	void setParentId(String parentId);
-
-	/**
-	 * Who is the parent of this item?
-	 * 
-	 * @return
-	 */
-	String getParentId();
-
-	/**
-	 * The uuid that belongs to the actual dataflow
-	 * 
-	 * @param workflowId
-	 */
-	void setWorkflowId(String workflowId);
-
-	/**
-	 * The uuid that belongs to the actual dataflow
-	 * 
-	 * @return a string representation of a uuid
-	 */
-	String getWorkflowId();
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/WorkflowDataProvenanceItem.java
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/WorkflowDataProvenanceItem.java b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/WorkflowDataProvenanceItem.java
deleted file mode 100644
index 88e0d75..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/WorkflowDataProvenanceItem.java
+++ /dev/null
@@ -1,101 +0,0 @@
-/*******************************************************************************
- * Copyright (C) 2007 The University of Manchester   
- * 
- *  Modifications to the initial code base are copyright of their
- *  respective authors, or their employers as appropriate.
- * 
- *  This program is free software; you can redistribute it and/or
- *  modify it under the terms of the GNU Lesser General Public License
- *  as published by the Free Software Foundation; either version 2.1 of
- *  the License, or (at your option) any later version.
- *    
- *  This program is distributed in the hope that it will be useful, but
- *  WITHOUT ANY WARRANTY; without even the implied warranty of
- *  MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the GNU
- *  Lesser General Public License for more details.
- *    
- *  You should have received a copy of the GNU Lesser General Public
- *  License along with this program; if not, write to the Free Software
- *  Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307
- ******************************************************************************/
-package net.sf.taverna.t2.provenance.item;
-
-import net.sf.taverna.t2.provenance.vocabulary.SharedVocabulary;
-import net.sf.taverna.t2.reference.ReferenceService;
-import net.sf.taverna.t2.reference.T2Reference;
-
-/**
- * When the {@link WorkflowInstanceFacade} for a processor receives a data token
- * one of these is created. This is especially important for data which flows
- * straight through a facade without going into the dispatch stack (a rare event
- * but it can happen)
- * 
- * @author Ian Dunlop
- */
-public class WorkflowDataProvenanceItem extends AbstractProvenanceItem {
-	private ReferenceService referenceService;
-	/** The port name that the data is for */
-	private String portName;
-	/** A reference to the data token received in the facade */
-	private T2Reference data;
-	private SharedVocabulary eventType = SharedVocabulary.WORKFLOW_DATA_EVENT_TYPE;
-	private boolean isFinal;
-	private int[] index;
-	private boolean isInputPort;
-
-	public boolean isInputPort() {
-		return isInputPort;
-	}
-
-	public void setInputPort(boolean isInputPort) {
-		this.isInputPort = isInputPort;
-	}
-
-	public WorkflowDataProvenanceItem() {
-	}
-
-	@Override
-	public SharedVocabulary getEventType() {
-		return eventType;
-	}
-
-	public void setPortName(String portName) {
-		this.portName = portName;
-	}
-
-	public String getPortName() {
-		return portName;
-	}
-
-	public void setData(T2Reference data) {
-		this.data = data;
-	}
-
-	public T2Reference getData() {
-		return data;
-	}
-
-	public void setReferenceService(ReferenceService referenceService) {
-		this.referenceService = referenceService;
-	}
-
-	public ReferenceService getReferenceService() {
-		return referenceService;
-	}
-
-	public void setIndex(int[] index) {
-		this.index = index;
-	}
-
-	public int[] getIndex() {
-		return index;
-	}
-
-	public void setFinal(boolean isFinal) {
-		this.isFinal = isFinal;
-	}
-
-	public boolean isFinal() {
-		return isFinal;
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-taverna-engine/blob/5f1ddb71/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/WorkflowProvenanceItem.java
----------------------------------------------------------------------
diff --git a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/WorkflowProvenanceItem.java b/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/WorkflowProvenanceItem.java
deleted file mode 100644
index 5e593d2..0000000
--- a/taverna-workflowmodel-api/src/main/java/net/sf/taverna/t2/provenance/item/WorkflowProvenanceItem.java
+++ /dev/null
@@ -1,101 +0,0 @@
-/*******************************************************************************
- * Copyright (C) 2007 The University of Manchester   
- * 
- *  Modifications to the initial code base are copyright of their
- *  respective authors, or their employers as appropriate.
- * 
- *  This program is free software; you can redistribute it and/or
- *  modify it under the terms of the GNU Lesser General Public License
- *  as published by the Free Software Foundation; either version 2.1 of
- *  the License, or (at your option) any later version.
- *    
- *  This program is distributed in the hope that it will be useful, but
- *  WITHOUT ANY WARRANTY; without even the implied warranty of
- *  MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the GNU
- *  Lesser General Public License for more details.
- *    
- *  You should have received a copy of the GNU Lesser General Public
- *  License along with this program; if not, write to the Free Software
- *  Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307
- ******************************************************************************/
-package net.sf.taverna.t2.provenance.item;
-
-import java.sql.Timestamp;
-
-import net.sf.taverna.t2.facade.WorkflowInstanceFacade;
-import net.sf.taverna.t2.provenance.vocabulary.SharedVocabulary;
-import net.sf.taverna.t2.workflowmodel.Dataflow;
-
-/**
- * The first {@link ProvenanceItem} that the {@link ProvenanceConnector} will
- * receive for a workflow run. Contains the {@link Dataflow} itself as well as
- * the process id for the {@link WorkflowInstanceFacade} (facadeX:dataflowY).
- * Its child is a {@link ProcessProvenanceItem} and parent is the UUID of the
- * {@link Dataflow} itself
- * 
- * @author Ian Dunlop
- * @author Paolo Missier
- * @author Stuart Owen
- */
-public class WorkflowProvenanceItem extends AbstractProvenanceItem {
-	private Dataflow dataflow;
-	private SharedVocabulary eventType = SharedVocabulary.WORKFLOW_EVENT_TYPE;
-	private int[] index;
-	private boolean isFinal;
-
-	private Timestamp invocationStarted;
-
-	public Timestamp getInvocationStarted() {
-		return invocationStarted;
-	}
-
-	public WorkflowProvenanceItem() {
-	}
-
-	public Dataflow getDataflow() {
-		return dataflow;
-	}
-
-	public void setDataflow(Dataflow dataflow) {
-		this.dataflow = dataflow;
-	}
-
-	@Override
-	public SharedVocabulary getEventType() {
-		return eventType;
-	}
-
-	/**
-	 * @return the index
-	 */
-	public int[] getIndex() {
-		return index;
-	}
-
-	/**
-	 * @param index
-	 *            the index to set
-	 */
-	public void setIndex(int[] index) {
-		this.index = index;
-	}
-
-	/**
-	 * @return the isFinal
-	 */
-	public boolean isFinal() {
-		return isFinal;
-	}
-
-	/**
-	 * @param isFinal
-	 *            the isFinal to set
-	 */
-	public void setFinal(boolean isFinal) {
-		this.isFinal = isFinal;
-	}
-
-	public void setInvocationStarted(Timestamp invocationStarted) {
-		this.invocationStarted = invocationStarted;
-	}
-}