You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@oodt.apache.org by ma...@apache.org on 2018/02/27 04:21:57 UTC

[01/14] oodt git commit: wip 1.0

Repository: oodt
Updated Branches:
  refs/heads/development 75d292cd2 -> d63616bba


wip 1.0


Project: http://git-wip-us.apache.org/repos/asf/oodt/repo
Commit: http://git-wip-us.apache.org/repos/asf/oodt/commit/dab58205
Tree: http://git-wip-us.apache.org/repos/asf/oodt/tree/dab58205
Diff: http://git-wip-us.apache.org/repos/asf/oodt/diff/dab58205

Branch: refs/heads/development
Commit: dab582059c58ab669c5b3b43a9d6c12989bd2806
Parents: f91720d
Author: Radu Manole <ma...@gmail.com>
Authored: Wed Aug 12 01:34:54 2015 +0300
Committer: Radu Manole <ma...@gmail.com>
Committed: Wed Aug 12 01:34:54 2015 +0300

----------------------------------------------------------------------
 commons/pom.xml                                 |  12 +
 .../org/apache/oodt/commons/AvroExecServer.java | 369 +++++++++++++++++++
 .../org/apache/oodt/commons/ExecServer.java     |   2 +-
 .../oodt/commons/AvroMultiServerTest.java       |  96 +++++
 4 files changed, 478 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/oodt/blob/dab58205/commons/pom.xml
----------------------------------------------------------------------
diff --git a/commons/pom.xml b/commons/pom.xml
index ed5f8ee..3703c12 100644
--- a/commons/pom.xml
+++ b/commons/pom.xml
@@ -105,6 +105,18 @@
     </profile>
   </profiles>
   <dependencies>
+
+    <dependency>
+      <groupId>org.apache.avro</groupId>
+      <artifactId>avro</artifactId>
+      <version>1.7.7</version>
+    </dependency>
+    <dependency>
+      <groupId>org.apache.avro</groupId>
+      <artifactId>avro-ipc</artifactId>
+      <version>1.7.7</version>
+    </dependency>
+
     <dependency>
       <groupId>commons-dbcp</groupId>
       <artifactId>commons-dbcp</artifactId>

http://git-wip-us.apache.org/repos/asf/oodt/blob/dab58205/commons/src/main/java/org/apache/oodt/commons/AvroExecServer.java
----------------------------------------------------------------------
diff --git a/commons/src/main/java/org/apache/oodt/commons/AvroExecServer.java b/commons/src/main/java/org/apache/oodt/commons/AvroExecServer.java
new file mode 100644
index 0000000..6aa5d40
--- /dev/null
+++ b/commons/src/main/java/org/apache/oodt/commons/AvroExecServer.java
@@ -0,0 +1,369 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.oodt.commons;
+
+import org.apache.avro.Protocol;
+import org.apache.avro.ipc.HttpServer;
+import org.apache.avro.ipc.Responder;
+import org.apache.avro.ipc.Server;
+import org.apache.avro.ipc.generic.GenericResponder;
+import org.apache.avro.ipc.specific.SpecificResponder;
+import org.apache.oodt.commons.io.Base64EncodingOutputStream;
+import org.apache.oodt.commons.util.LogInit;
+import org.apache.oodt.commons.util.XML;
+import org.apache.xmlrpc.XmlRpcServer;
+import org.w3c.dom.DOMException;
+import org.w3c.dom.Document;
+import org.w3c.dom.DocumentType;
+import org.w3c.dom.Element;
+import org.xml.sax.SAXException;
+import org.xml.sax.SAXParseException;
+
+import javax.naming.Context;
+import javax.naming.NamingException;
+import java.io.IOException;
+import java.io.ObjectOutputStream;
+import java.lang.reflect.Constructor;
+import java.lang.reflect.InvocationTargetException;
+import java.net.InetAddress;
+import java.net.UnknownHostException;
+import java.rmi.server.RemoteObject;
+import java.rmi.server.RemoteRef;
+import java.rmi.server.RemoteStub;
+import java.util.Date;
+import java.util.Iterator;
+
+public class AvroExecServer {
+
+    /** The configuration. */
+    private static Configuration configuration;
+
+    /** The servant. */
+    private Object servant;
+
+
+    /** Current binder, if any. */
+    private static Binder binder;
+
+    /** Object key name. */
+    protected String name;
+
+    /** Server's status document. */
+    private Document statusDocument;
+
+    /** The &lt;log&gt; element within the status document. */
+    private Element logElement;
+
+    /** The XML-RPC interface to this server. */
+    private HttpServer server;
+
+
+    /** Status DTD Document Type Definition formal public identifier. */
+    public static final String STATUS_FPI = "-//JPL//DTD EDA Server Status 1.0";
+
+    /** Status DTD system identifier. */
+    public static final String STATUS_URL = "http://oodt.jpl.nasa.gov/edm-commons/xml/serverStatus.dtd";
+
+    /** Name of the property that prints the server's IOR or RMI handle. */
+    public static final String PRINT_IOR_PROPERTY = "org.apache.oodt.commons.ExecServer.printIOR";
+
+    /** Name of the property that prevents binding of this object with the naming service. */
+    public static final String DISABLE_BINDING = "org.apache.oodt.commons.ExecServer.disableBinding";
+
+    /** How long to wait before bind attempts, in ms. */
+    private static final long REBIND_PERIOD = Long.getLong("org.apache.oodt.commons.ExecServer.rebindPeriod", 30*60*1000).longValue();
+
+
+    protected AvroExecServer(String name) {
+        this.name = name;
+    }
+
+    /** Create a new executable server.
+     *
+     * @param name Name of the server
+     * @param className Name of class that implements the server.
+     * @throws ClassNotFoundException If the class for <var>className</var> can't be found.
+     * @throws NoSuchMethodException If the constructor for <var>className</var> taking a single <code>ExecServer</code>
+     *         can't be found.
+     * @throws InstantiationException If the class for <var>className</var> is abstract or is an interface.
+     * @throws IllegalAccessException If the class for <var>className</var> isn't public.
+     * @throws InvocationTargetException If an exception occurs in the constructor for <var>className</var>.
+     * @throws DOMException If the server's status document can't be created.
+     * @throws UnknownHostException If the local host name can't be determined.
+     */
+    public AvroExecServer(String name, String className) throws ClassNotFoundException, NoSuchMethodException,
+            InstantiationException, IllegalAccessException, InvocationTargetException, DOMException, UnknownHostException {
+        this.name = name;
+
+        // Find the class and the required constructor.
+        Class clazz = Class.forName(className);
+        Constructor ctor = clazz.getConstructor(new Class[]{ExecServer.class});
+
+        // Invoke the constructor to create the servant.
+        servant = ctor.newInstance(new Object[]{this});
+        Date startDate = new Date();
+
+        // Create the XML-RPC interface to this server.
+
+        // I should create avro interface to this server
+
+        Responder responder = new GenericResponder() {
+            @Override
+            public Object respond(Protocol.Message message, Object o) throws Exception {
+
+                return null;
+            }
+        }
+        server =new HttpServer();
+        server.
+
+//        xmlrpcServer = new XmlRpcServer();
+//        xmlrpcServer.addHandler("server", this);
+
+        // Create the server status document.
+        DocumentType docType = XML.getDOMImplementation().createDocumentType("server", STATUS_FPI, STATUS_URL);
+        statusDocument = XML.getDOMImplementation().createDocument(/*namespaceURI*/null, "server", docType);
+        Element serverElement = statusDocument.getDocumentElement();
+        XML.add(serverElement, "name", name);
+        XML.add(serverElement, "class", className);
+        XML.add(serverElement, "state", "up");
+        Element startElement = statusDocument.createElement("start");
+        serverElement.appendChild(startElement);
+        Element userElement = statusDocument.createElement("user");
+        startElement.appendChild(userElement);
+        XML.add(userElement, "name", System.getProperty("user.name", "UNKNOWN"));
+        XML.add(userElement, "cwd", System.getProperty("user.dir", "UNKNOWN"));
+        XML.add(userElement, "home", System.getProperty("user.home", "UNKNOWN"));
+        Element dateElement = statusDocument.createElement("date");
+        startElement.appendChild(dateElement);
+        dateElement.setAttribute("ms", String.valueOf(startDate.getTime()));
+        dateElement.appendChild(statusDocument.createTextNode(startDate.toString()));
+        XML.add(startElement, "config", System.getProperty("org.apache.oodt.commons.Configuration.url", "UNKNOWN"));
+        Element hostElement = statusDocument.createElement("host");
+        serverElement.appendChild(hostElement);
+        XML.add(hostElement, "name", InetAddress.getLocalHost().getHostName());
+        Element osElement = statusDocument.createElement("os");
+        hostElement.appendChild(osElement);
+        XML.add(osElement, "name", System.getProperty("os.name", "UNKNOWN"));
+        XML.add(osElement, "version", System.getProperty("os.version", "UNKNOWN"));
+        XML.add(osElement, "arch", System.getProperty("os.arch", "UNKNOWN"));
+        Element vmElement = statusDocument.createElement("vm");
+        serverElement.appendChild(vmElement);
+        XML.add(vmElement, "name", System.getProperty("java.vm.name", "UNKNOWN"));
+        XML.add(vmElement, "version", System.getProperty("java.version", "UNKNOWN"));
+        XML.add(vmElement, "classpath", System.getProperty("java.class.path", "UNKNOWN"));
+        XML.add(vmElement, "extdirs", System.getProperty("java.ext.dirs", "UNKNOWN"));
+        logElement = statusDocument.createElement("log");
+        serverElement.appendChild(logElement);
+    }
+
+
+    public static void runInitializers() throws EDAException {
+        String initList = System.getProperty("org.apache.oodt.commons.initializers",
+                System.getProperty("org.apache.oodt.commons.ExecServer.initializers", System.getProperty("initializers", "")));
+        for (Iterator i = org.apache.oodt.commons.util.Utility.parseCommaList(initList); i.hasNext();) {
+            String iname = (String) i.next();
+            try {
+                Class initClass = Class.forName(iname);
+                Initializer init = (Initializer) initClass.newInstance();
+                init.initialize();
+            } catch (ClassNotFoundException ex) {
+                System.err.println("Initializer \"" + iname + "\" not found; aborting");
+                throw new EDAException(ex);
+            } catch (InstantiationException ex) {
+                System.err.println("Initializer \"" + iname + "\" is abstract; aborting");
+                throw new EDAException(ex);
+            } catch (IllegalAccessException ex) {
+                System.err.println("Initializer \"" + iname + "\" isn't public; aborting");
+                throw new EDAException(ex);
+            } catch (EDAException ex) {
+                System.err.println("Initializer \"" + iname + "\" failed: " + ex.getMessage());
+                throw new EDAException(ex);
+            }
+        }
+    }
+
+    public static void main(String[] argv) {
+        if (argv.length < 2) {
+            System.err.println("Usage: class-name-of-server object-name");
+            System.exit(1);
+        }
+
+        String className = argv[0];
+        String name = argv[1];
+
+        // Enable support of our special URLs, like stdin:
+        System.setProperty("java.protocol.handler.pkgs", "org.apache.oodt.commons.net.protocol");
+
+        try {
+            // Get the configuration.
+            configuration = Configuration.getConfiguration();
+            configuration.mergeProperties(System.getProperties());
+
+            // Set up the logger.
+            LogInit.init(System.getProperties(), name);
+
+            // Run initializers
+            try {
+                runInitializers();
+            } catch (EDAException ex) {
+                ex.printStackTrace();
+                System.exit(1);
+            }
+
+            // Create it.
+            final AvroExecServer server = new AvroExecServer(name, className);
+
+            // Print it.
+            if (Boolean.getBoolean(PRINT_IOR_PROPERTY)) {
+                if (server.getServant() instanceof RemoteObject) {
+                    RemoteObject remoteObject = (RemoteObject) server.getServant();
+                    RemoteStub remoteStub = (RemoteStub) RemoteObject.toStub(remoteObject);
+                    RemoteRef ref = remoteStub.getRef();
+                    System.out.print("RMI:");
+                    System.out.flush();
+                    ObjectOutputStream objOut
+                            = new ObjectOutputStream(new Base64EncodingOutputStream(System.out));
+                    objOut.writeObject(ref);
+                    objOut.flush();
+                    System.out.println();
+                } else {
+                    org.omg.PortableServer.Servant servant=(org.omg.PortableServer.Servant)server.getServant();
+                    org.omg.CORBA.ORB orb = servant._orb();
+                    System.out.println(orb.object_to_string(servant._this_object(orb)));
+                }
+                System.out.flush();
+            }
+
+            // Bind it.
+            if (!Boolean.getBoolean(DISABLE_BINDING)) {
+                binder = new Binder(name, server);
+                binder.start();
+            }
+
+            // Prepare for the inevitable
+            Runtime.getRuntime().addShutdownHook(new Thread() {
+                public void run() {
+                    server.shutdown0();
+                }
+            });
+
+            // We're done here.
+            for (;;) try {
+                Thread.currentThread().join();
+            } catch (InterruptedException ignore) {}
+        } catch (IOException ex) {
+            System.err.println("I/O error during initialization: " + ex.getMessage());
+            ex.printStackTrace();
+        } catch (SAXParseException ex) {
+            System.err.println("Error in the configuration file at line " + ex.getLineNumber() + ", column "
+                    + ex.getColumnNumber() + ": " + ex.getMessage());
+        } catch (SAXException ex) {
+            System.err.println("Error " + ex.getClass().getName() + " while attempting to parse the configuration"
+                    + " file: " + ex.getMessage());
+        } catch (javax.naming.NamingException ex) {
+            System.err.println("Naming/directory error: " + ex.getClass().getName() + ": " + ex.getMessage());
+        } catch (java.lang.reflect.InvocationTargetException ex) {
+            Throwable target = ex.getTargetException();
+            System.err.println("Constructor for \"" + className + "\" threw " + target.getClass().getName() + ": "
+                    + ex.getMessage());
+            target.printStackTrace();
+        } catch (RuntimeException ex) {
+            throw ex;
+        } catch (Exception ex) {
+            System.err.println("Exception " + ex.getClass().getName() + " initializing server \"" + name
+                    + "\" with class \"" + className + "\": " + ex.getMessage());
+            ex.printStackTrace();
+        }
+        System.exit(1);
+    }
+
+    /**
+     * Binding thread.
+     */
+    private static class Binder extends Thread {
+        private boolean keepBinding;
+        private String name;
+        private AvroExecServer server;
+        public Binder(String name, AvroExecServer server) {
+            super("Binder for " + name);
+            setDaemon(true);
+            this.name = name;
+            this.server = server;
+            keepBinding = true;
+        }
+        public void run() {
+            while (shouldKeepBinding()) try {
+                Context objectContext = configuration.getObjectContext();
+                objectContext.rebind(name, server.getServant());
+                objectContext.close();
+            } catch (Throwable ex) {
+                System.err.println("Exception binding at " + new Date() + "; will keep trying...");
+                ex.printStackTrace();
+            } finally {
+                try {
+                    Thread.sleep(REBIND_PERIOD);
+                } catch (InterruptedException ignore) {}
+            }
+        }
+        public synchronized void stopBinding() {
+            keepBinding = false;
+        }
+        private synchronized boolean shouldKeepBinding() {
+            return keepBinding;
+        }
+
+    }
+
+    /** Return the servant for this executable server.
+     *
+     * @return The servant.
+     */
+    public Object getServant() {
+        return servant;
+    }
+
+    private void shutdown0() {
+        // Unbind.
+        if (!Boolean.getBoolean(DISABLE_BINDING)) try {
+            binder.stopBinding();
+            Context objectContext = configuration.getObjectContext();
+            objectContext.unbind(getName());
+            objectContext.close();
+        } catch (NamingException ignore) {}
+
+        // Kill the ORB.  YEAH!  KILL IT, KILL IT, KIIIIIIIIIIIIIIL IIIIIIIIT!!!!!!!1
+        try {
+            if (servant instanceof org.omg.PortableServer.Servant) {
+                org.omg.PortableServer.Servant s = (org.omg.PortableServer.Servant) servant;
+                org.omg.CORBA.ORB orb = s._orb();
+                orb.shutdown(false/*=>terminate without waiting for reqs to complete*/);
+            }
+        } catch (Throwable ignore) {}
+    }
+
+    /** Get my name.
+     *
+     * @return The name under which I'm registered in teh naming context.
+     */
+    public String getName() {
+        return name;
+    }
+
+
+}

http://git-wip-us.apache.org/repos/asf/oodt/blob/dab58205/commons/src/main/java/org/apache/oodt/commons/ExecServer.java
----------------------------------------------------------------------
diff --git a/commons/src/main/java/org/apache/oodt/commons/ExecServer.java b/commons/src/main/java/org/apache/oodt/commons/ExecServer.java
index 9e8293d..60a6894 100644
--- a/commons/src/main/java/org/apache/oodt/commons/ExecServer.java
+++ b/commons/src/main/java/org/apache/oodt/commons/ExecServer.java
@@ -459,7 +459,7 @@ public class ExecServer {
 
 	/** Status DTD formal public identifier. */
 	public static final String STATUS_FPI = "-//JPL//DTD EDA Server Status 1.0";
-	
+
 	/** Status DTD system identifier. */
 	public static final String STATUS_URL = "http://oodt.jpl.nasa.gov/edm-commons/xml/serverStatus.dtd";
 

http://git-wip-us.apache.org/repos/asf/oodt/blob/dab58205/commons/src/test/java/org/apache/oodt/commons/AvroMultiServerTest.java
----------------------------------------------------------------------
diff --git a/commons/src/test/java/org/apache/oodt/commons/AvroMultiServerTest.java b/commons/src/test/java/org/apache/oodt/commons/AvroMultiServerTest.java
new file mode 100644
index 0000000..4904bc5
--- /dev/null
+++ b/commons/src/test/java/org/apache/oodt/commons/AvroMultiServerTest.java
@@ -0,0 +1,96 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.oodt.commons;
+
+import junit.framework.TestCase;
+import org.xml.sax.InputSource;
+import org.xml.sax.SAXException;
+
+import javax.xml.parsers.ParserConfigurationException;
+import java.io.IOException;
+import java.io.InputStream;
+import java.lang.reflect.InvocationTargetException;
+import java.rmi.server.RemoteObject;
+
+public class AvroMultiServerTest extends TestCase {
+
+    private InputStream testConfig;
+
+    public AvroMultiServerTest(String name) {
+        super(name);
+    }
+
+    protected void setUp() throws Exception {
+        super.setUp();
+        testConfig = getClass().getResourceAsStream("/test-multiserver.xml");
+        if (testConfig == null) throw new IOException("Cannot find `test-multiserver.xml'");
+        System.setProperty("my.other.setting", "Don't override");
+    }
+
+    public void tearDown() throws Exception {
+        if (testConfig != null) try {
+            testConfig.close();
+        } catch (IOException ignore) {}
+        System.getProperties().remove("my.setting");
+        System.getProperties().remove("my.other.setting");
+        super.tearDown();
+    }
+
+    public static class Svr1 extends RemoteObject {
+        public Svr1(ExecServer e) {}
+    }
+    public static class Svr2 extends RemoteObject {
+        public Svr2(ExecServer e) {}
+    }
+    public static class Svr3 extends RemoteObject {
+        public Svr3(ExecServer e) {}
+    }
+    public static class Svr4 extends RemoteObject {
+        public Svr4(ExecServer e) {}
+    }
+
+
+    public void testParsing() throws ParserConfigurationException, SAXException, IOException, ClassNotFoundException,
+            NoSuchMethodException, InstantiationException, IllegalAccessException, InvocationTargetException {
+        InputSource is = new InputSource(testConfig);
+        MultiServer.parseConfig(is);
+        assertEquals("test.app", MultiServer.getAppName());
+        assertEquals(4, MultiServer.getServers().size());
+
+        MultiServer.Server server = (MultiServer.Server) MultiServer.getServers().get("urn:eda:rmi:Test1");
+        assertEquals("org.apache.oodt.commons.MultiServerTest$Svr1", server.getClassName());
+        assertEquals(MultiServer.BINDING, server.getBindingBehavior());
+
+        server = (MultiServer.Server) MultiServer.getServers().get("urn:eda:rmi:Test2");
+        assertEquals("org.apache.oodt.commons.MultiServerTest$Svr2", server.getClassName());
+        assertEquals(MultiServer.NONBINDING, server.getBindingBehavior());
+
+        server = (MultiServer.Server) MultiServer.getServers().get("urn:eda:rmi:Test3");
+        assertEquals("org.apache.oodt.commons.MultiServerTest$Svr3", server.getClassName());
+        assertEquals(MultiServer.REBINDING, server.getBindingBehavior());
+
+        MultiServer.AutobindingServer s = (MultiServer.AutobindingServer) MultiServer.getServers().get("urn:eda:rmi:Test4");
+        assertEquals("org.apache.oodt.commons.MultiServerTest$Svr4", s.getClassName());
+        assertEquals(MultiServer.AUTO, s.getBindingBehavior());
+        assertEquals(360000L, s.getPeriod());
+
+        assertEquals("My Value", System.getProperty("my.setting"));
+        assertEquals("Don't override", System.getProperty("my.other.setting"));
+    }
+
+}


[12/14] oodt git commit: Merge branch 'master' into OODT-972

Posted by ma...@apache.org.
Merge branch 'master' into OODT-972


Project: http://git-wip-us.apache.org/repos/asf/oodt/repo
Commit: http://git-wip-us.apache.org/repos/asf/oodt/commit/9e5d75d5
Tree: http://git-wip-us.apache.org/repos/asf/oodt/tree/9e5d75d5
Diff: http://git-wip-us.apache.org/repos/asf/oodt/diff/9e5d75d5

Branch: refs/heads/development
Commit: 9e5d75d5ea03b3d2aacb991494923beca0fe5c3e
Parents: 73e8e85 33d64a6
Author: Chris Mattmann <ch...@jpl.nasa.gov>
Authored: Fri Feb 23 09:34:24 2018 -0800
Committer: Chris Mattmann <ch...@jpl.nasa.gov>
Committed: Fri Feb 23 09:34:24 2018 -0800

----------------------------------------------------------------------
 CHANGES.txt | 13 ++++++++++++-
 1 file changed, 12 insertions(+), 1 deletion(-)
----------------------------------------------------------------------



[11/14] oodt git commit: Record change for OODT-972; bring 1.2.2 release changes in. Change current master to 1.9

Posted by ma...@apache.org.
Record change for OODT-972; bring 1.2.2 release changes in. Change current master to 1.9


Project: http://git-wip-us.apache.org/repos/asf/oodt/repo
Commit: http://git-wip-us.apache.org/repos/asf/oodt/commit/33d64a6d
Tree: http://git-wip-us.apache.org/repos/asf/oodt/tree/33d64a6d
Diff: http://git-wip-us.apache.org/repos/asf/oodt/diff/33d64a6d

Branch: refs/heads/development
Commit: 33d64a6dcb1672ea1eedec74d2a30a5f8e3d340a
Parents: 13d4176
Author: Chris Mattmann <ch...@jpl.nasa.gov>
Authored: Fri Feb 23 09:31:26 2018 -0800
Committer: Chris Mattmann <ch...@jpl.nasa.gov>
Committed: Fri Feb 23 09:31:26 2018 -0800

----------------------------------------------------------------------
 CHANGES.txt | 13 ++++++++++++-
 1 file changed, 12 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/oodt/blob/33d64a6d/CHANGES.txt
----------------------------------------------------------------------
diff --git a/CHANGES.txt b/CHANGES.txt
index e9861c5..5323db1 100644
--- a/CHANGES.txt
+++ b/CHANGES.txt
@@ -2,14 +2,25 @@ Apache OODT Change Log
 ======================
 
 =======
-Release 1.3 - In Progress
+Release 1.9 - In Progress
+
+* OODT-972 Add filemgr.server and filemgr.client configuration keys to Radix filemgr.properties (lewismc via mattmann)
 
 * OODT-964, OODT-963 Fix issues merging Distributed ZK Config module into Avro-RPC branch (imesha,mattmann)
+
 * OODT-957 Add CVE reporting plugin to maven build chain
+
 * OODT-958 Update commons-collections
+
 * OODT-959 Update tika to 1.16
 
 =======
+Release 1.2.2 - 02/05/2018
+
+* OODT-968 Add metadata removes product
+
+
+=======
 Release 1.2.1 - 11/10/2017
 
 * OODT-967 Solr version for 1.2.1 breaks SolrDumper in File Manager (mattmann)


[07/14] oodt git commit: Add my new key.

Posted by ma...@apache.org.
Add my new key.


Project: http://git-wip-us.apache.org/repos/asf/oodt/repo
Commit: http://git-wip-us.apache.org/repos/asf/oodt/commit/9f48fea1
Tree: http://git-wip-us.apache.org/repos/asf/oodt/tree/9f48fea1
Diff: http://git-wip-us.apache.org/repos/asf/oodt/diff/9f48fea1

Branch: refs/heads/development
Commit: 9f48fea19e629a457436312ab5657942800a1eae
Parents: df9bdc2
Author: Chris Mattmann <ch...@jpl.nasa.gov>
Authored: Sun Nov 12 09:45:12 2017 -0800
Committer: Chris Mattmann <ch...@jpl.nasa.gov>
Committed: Sun Nov 12 09:45:12 2017 -0800

----------------------------------------------------------------------
 KEYS | 52 ++++++++++++++++++++++++++++++++++++++++++++++++++++
 1 file changed, 52 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/oodt/blob/9f48fea1/KEYS
----------------------------------------------------------------------
diff --git a/KEYS b/KEYS
index 1dc1aeb..c4f360c 100644
--- a/KEYS
+++ b/KEYS
@@ -381,4 +381,56 @@ EIvrvgOqcmbISxQJ/R0KBc96ResburE22I3Gw05x/HBBXtgolMKiqu8Z1Ndkl4vm
 YPi9ISfsd7U8El0OiV2G0PY=
 =YRz1
 -----END PGP PUBLIC KEY BLOCK-----
+-----BEGIN PGP PUBLIC KEY BLOCK-----
+
+mQINBFoGZGwBEAC5XkLUgiTa91znq7+TYgBQTRagToG4S702+gqtgN9NawSvAtiY
+aMj+No5wPKzII5tsAWIg8aa28ZN4WDYD3nW6gCPUdAS/2/Yp+dNRW6cU54g6YlrL
+AAdyeBTdbjkKgAXxmP/MVHTXfFwBeSOV7uuGbPEdrSDlCW0lp+7E/BB2Jcu4kD5K
+mvdV/aaVAgf/AbQB0RFldxKHwOY/WY7iZzV0jsKAfX5IDrwl9HQiW3BfzxYROftD
+mvEKGr34S73QGbgaXx6a69BOkQA6DUAg9ISU//FLbaRsfn4lOF+cj7QzC1b6NjMj
+S6rLy+fMMmCSiRw3r6W6nfh0xLaHFfVI3M2o4rDzD+xWvKayDFKjm9vQ9jRJKW9C
+TshtDKCtFpasHjjXqe6z4P78QLH0quqsjJKQ4XkEAEHlELUqn683EJBtxbkYqUZw
+LEbcsSDia56J1yP9NCI8BfkfDDRT7Z7Pm2fyxHdK4V7dIZj+di6KylF1NXSQrTjJ
+zvJ6KmeGZFammrm/cVajU8l5/0sr7UOWZhdeu49MdGWDZB24M5wy0gYuD5yjVQGP
+rUDyX/UMzR7t7VxkpTFrn3wiVyvOzeZ4q667hySM41ZFJc/zmm5kM9lvWLgL/zJ4
+VhDBD+aZYIh1Wb7Fhan1dFCyZQ8zXiHXf9wvSdrS3EIT14fIPzWfr60XXQARAQAB
+tCRDaHJpcyBNYXR0bWFubiA8bWF0dG1hbm5AYXBhY2hlLm9yZz6JAlQEEwEIAD4W
+IQQndT9E5BXcrf55AMYrEicb/QH+2wUCWgZkbAIbAwUJB4YfgAULCQgHAgYVCAkK
+CwIEFgIDAQIeAQIXgAAKCRArEicb/QH+21PtD/9Tuhdw/igNtkPZd38ha0BbDUeS
+E/rlTpJ+1AZzj3oGsD36TDkwrDVa/BBTminM+Z1OAdlPp5shKOM0aOGQ63W0BG2K
+cqCptKyVcWE8Q/Al9A40ZMDHYV8mxr+udYzl+1TFfG+7wHlCP3//N2TSt3Cjlg9+
+sjXEBduM/S5oDMuc17tEnYqpBQ9qZ8Di4InDk+9MtSI+tJ4IfxwkDSe6u56db3Wr
+Sf2sO7A4JylK1osfujk1g5/hOPgaxjDd6g8+qgO7a87byi93Oe1VFtAw38RN267D
+4PA9cuUhlnFIqQ8j1OQh/aTwqxH5qxSG8JOzVLaoMl7wQtOAKL3cMr1JmgVh0am0
+bYYvwB+6u0p+RM3Itk5mzpZs5Hl2xms8S3VOw9EWWLrbAYqsrtOC+SJbWM3oG6XB
+s1oS3gV75TyVszwB5UqmazHStG/J52mek9YUM7/0vGwgpaOJt4BwDhtkCGiIY+UY
+jnOPE/avDt1c0B28ZNNOWD8zrat7BQpyOOciDJ9orCRstrfxOvMB16+Wszsuhlch
++MP66uLDvxtRlmBbqIxl0Y+J7Ecpo/x3dwV60Bnuc71Ewo5Wi7/d2U8wHSCUKN0+
+SNE6cThnW6fx9ZZd3OYsaZ/wJGYgrEtSADIpmwcii90lRRAMnd/jDTx46dxccxTO
+zv2fLzZlPOavohrRSrkCDQRaBmRsARAA5eM9f+veu5brztAG3v72sCEYfWC+E+Od
+7BVJg+cyBgJ2HZ3IqQDql+PQFBaw/SASKSIhjckd2l6IvgM9fCZk+aRCzlNEgx5Z
+RQJEgaqsvjir+wqPg9uYKBiM9XFEBc5Ig4SVnyIMDiv9s2BUNWOeGbVir//qSTPe
+SdUZMk8GZZpSjVO/1Qp7kYpeq2ScCKEcm0hQzuWdB4abPIeEZg3q/bhAVmbmOetR
+wrvLDHugJ9m34ZyL/TRMtRplEEgjsHWA88oJ9+w8NHyb1wLikeGdlwcCYDRoQphl
+8DOmqaMKLsI4vex47UNMkO2d33Jt5cbvJC5oo7u8+VxeQMtNOQBS6SVflYb8iUvT
+AErpzmzTVbm/uDQm2WZOHrYSwrUi/6Uitgs57VnkIf3Xl6JpNqF44ND4alRTXu1Q
+c+ghx1W45Ye2Jf+oAz2o3U/noh5XVA38Z1AU5FwVZG4yukBM6r/iJHXIUNc0Cg3G
+bMOlVeXOdDc5MDUr51v+Qf6+uDAKVX4WguJqNgfbq//M9hG5mi0Eh3zikLMFmbSO
+6VeqwjQMkZCc2e0CT1vSLdSUXn4YWIAytLKp10lv1cTRJKNRfdZE0npimylXtiLI
+Ma1PCd1htKvbCBUEpdg4CkFKnC6zs+GLKM9LHEoBkGOeYIPqvprVsnEteIwT6r8E
+oA88zpMGGcEAEQEAAYkCPAQYAQgAJhYhBCd1P0TkFdyt/nkAxisSJxv9Af7bBQJa
+BmRsAhsMBQkHhh+AAAoJECsSJxv9Af7bvnYP/2gUc0qXmWUfS2BAxA6gpR4GgRQD
+T/nHhosgICu2FYy3aY+mHXOE9VRHgU7QwEyBGN+akuOVN/7N/suZEshoYqPraoqQ
+1csSofP+c8eTJBS1MW68G+Bt2JbN3pIJ5Kfgikx5tscniWb7eiGu3n+7ffiXrVO4
+Dv6mpaehxtcwtse4hLOCZ7zApmDReYCQsOaF0jNXGq9UfkPF8MgMHuvYrbnDJQxx
+YqI1IgUhY9Jn5aGo4noMYAyeRikiOtV+/orNIaAUzVfcARbI61Rz4JpxYNMON+Hc
+CMI5cAITypHMdWr/crO4Lz6P0SK1/qFCT1jvyZBKslX/E4QITFytL2G+/9MSqDcc
+nv7+5rGV97S4aEm81rO69LdLwgBcCu/ZOorM67FACKaS/oXuJ4Pj0VlQRmqRWKk3
+m7weYQoQVJGX5luRegbxHvhAG62J2RO1jSW+AXV+ivo7hMSpAws5UqLXOOfyv5+M
+nL5t6rJ405h8ta29vvVc7GbrZUurCvYnCUh8E07zur82TiFAa0QmNKbVS+TLQekD
+0QMcVvvrR8nZ81C1I2UBe1+ehDYJR0cFIq2KEMdULjd1t2v9wOQzrutqsi+QL/RX
+63Pg9KThRJ6ADLCoIVzjL7wOCoK63XC+09C62HX3U7jxvwcWfxtOW1fMxt+7FTVI
+XspLWMR3MwLmO4Rd
+=yY66
+-----END PGP PUBLIC KEY BLOCK-----
 


[02/14] oodt git commit: Resolve conflicts.

Posted by ma...@apache.org.
Resolve conflicts.


Project: http://git-wip-us.apache.org/repos/asf/oodt/repo
Commit: http://git-wip-us.apache.org/repos/asf/oodt/commit/401f2416
Tree: http://git-wip-us.apache.org/repos/asf/oodt/tree/401f2416
Diff: http://git-wip-us.apache.org/repos/asf/oodt/diff/401f2416

Branch: refs/heads/development
Commit: 401f241696781fbb46ba56f43d71c6878a2913b0
Parents: 5794ec3 dab5820
Author: Chris Mattmann <ch...@jpl.nasa.gov>
Authored: Fri Oct 13 22:48:24 2017 -0700
Committer: Chris Mattmann <ch...@jpl.nasa.gov>
Committed: Fri Oct 13 22:48:24 2017 -0700

----------------------------------------------------------------------
 commons/pom.xml                                 |  72 ++++
 .../org/apache/oodt/commons/AvroExecServer.java | 369 +++++++++++++++++++
 .../org/apache/oodt/commons/ExecServer.java     |   2 +-
 .../oodt/commons/AvroMultiServerTest.java       |  96 +++++
 4 files changed, 538 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/oodt/blob/401f2416/commons/pom.xml
----------------------------------------------------------------------
diff --cc commons/pom.xml
index d5108a2,3703c12..cf54eba
--- a/commons/pom.xml
+++ b/commons/pom.xml
@@@ -177,4 -104,74 +177,76 @@@
        </build>
      </profile>
    </profiles>
++<<<<<<< HEAD
++=======
+   <dependencies>
+ 
+     <dependency>
+       <groupId>org.apache.avro</groupId>
+       <artifactId>avro</artifactId>
+       <version>1.7.7</version>
+     </dependency>
+     <dependency>
+       <groupId>org.apache.avro</groupId>
+       <artifactId>avro-ipc</artifactId>
+       <version>1.7.7</version>
+     </dependency>
+ 
+     <dependency>
+       <groupId>commons-dbcp</groupId>
+       <artifactId>commons-dbcp</artifactId>
+       <version>1.2.1</version>
+     </dependency>
+     <dependency>
+       <groupId>commons-collections</groupId>
+       <artifactId>commons-collections</artifactId>
+       <version>2.1</version>
+     </dependency>
+     <dependency>
+       <groupId>commons-pool</groupId>
+       <artifactId>commons-pool</artifactId>
+       <version>1.2</version>
+     </dependency>
+     <dependency>
+       <groupId>commons-lang</groupId>
+       <artifactId>commons-lang</artifactId>
+       <version>2.3</version>
+     </dependency>
+     <dependency>
+       <groupId>commons-logging</groupId>
+       <artifactId>commons-logging</artifactId>
+       <version>1.0.3</version>
+     </dependency>
+     <dependency>
+       <groupId>org.springframework</groupId>
+       <artifactId>spring-core</artifactId>
+       <version>2.5.4</version>
+     </dependency>
+     <dependency>
+       <groupId>org.springframework</groupId>
+       <artifactId>spring-hibernate3</artifactId>
+       <version>2.0.8</version>
+       <exclusions>
+         <exclusion>
+           <groupId>javax.transaction</groupId>
+           <artifactId>jta</artifactId>
+         </exclusion>
+       </exclusions>
+     </dependency>
+     <dependency>
+         <groupId>xmlrpc</groupId>
+         <artifactId>xmlrpc</artifactId>
+         <version>2.0.1</version>
+     </dependency>
+     <dependency>
+       <groupId>junit</groupId>
+       <artifactId>junit</artifactId>
+       <version>3.8.2</version>
+     </dependency>
+     <dependency>
+         <groupId>xerces</groupId>
+         <artifactId>xercesImpl</artifactId>
+         <version>2.9.1</version>
+     </dependency>
+   </dependencies>
  </project>

http://git-wip-us.apache.org/repos/asf/oodt/blob/401f2416/commons/src/main/java/org/apache/oodt/commons/ExecServer.java
----------------------------------------------------------------------


[04/14] oodt git commit: finish cleaning up merge errors.

Posted by ma...@apache.org.
finish cleaning up merge errors.


Project: http://git-wip-us.apache.org/repos/asf/oodt/repo
Commit: http://git-wip-us.apache.org/repos/asf/oodt/commit/f8e7d956
Tree: http://git-wip-us.apache.org/repos/asf/oodt/tree/f8e7d956
Diff: http://git-wip-us.apache.org/repos/asf/oodt/diff/f8e7d956

Branch: refs/heads/development
Commit: f8e7d95696f8e32e08f86572adbc5d529cb4dc06
Parents: 55b0f00
Author: Chris Mattmann <ch...@jpl.nasa.gov>
Authored: Fri Oct 13 22:57:27 2017 -0700
Committer: Chris Mattmann <ch...@jpl.nasa.gov>
Committed: Fri Oct 13 22:57:27 2017 -0700

----------------------------------------------------------------------
 commons/pom.xml | 85 ++++++++++------------------------------------------
 1 file changed, 15 insertions(+), 70 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/oodt/blob/f8e7d956/commons/pom.xml
----------------------------------------------------------------------
diff --git a/commons/pom.xml b/commons/pom.xml
index 5054be3..67b19ba 100644
--- a/commons/pom.xml
+++ b/commons/pom.xml
@@ -97,8 +97,22 @@
     <dependency>
       <groupId>joda-time</groupId>
       <artifactId>joda-time</artifactId>
-      <version>2.9.4</version>
     </dependency>
+    <dependency>
+      <groupId>org.apache.avro</groupId>
+      <artifactId>avro</artifactId>
+      <version>1.7.7</version>
+    </dependency>
+    <dependency>
+      <groupId>org.apache.avro</groupId>
+      <artifactId>avro-ipc</artifactId>
+      <version>1.7.7</version>
+    </dependency>
+
+
+
+  
+  
   </dependencies>
   <build>
     <resources>
@@ -177,73 +191,4 @@
       </build>
     </profile>
   </profiles>
-  <dependencies>
-    <dependency>
-      <groupId>org.apache.avro</groupId>
-      <artifactId>avro</artifactId>
-      <version>1.7.7</version>
-    </dependency>
-    <dependency>
-      <groupId>org.apache.avro</groupId>
-      <artifactId>avro-ipc</artifactId>
-      <version>1.7.7</version>
-    </dependency>
-
-    <dependency>
-      <groupId>commons-dbcp</groupId>
-      <artifactId>commons-dbcp</artifactId>
-      <version>1.2.1</version>
-    </dependency>
-    <dependency>
-      <groupId>commons-collections</groupId>
-      <artifactId>commons-collections</artifactId>
-      <version>2.1</version>
-    </dependency>
-    <dependency>
-      <groupId>commons-pool</groupId>
-      <artifactId>commons-pool</artifactId>
-      <version>1.2</version>
-    </dependency>
-    <dependency>
-      <groupId>commons-lang</groupId>
-      <artifactId>commons-lang</artifactId>
-      <version>2.3</version>
-    </dependency>
-    <dependency>
-      <groupId>commons-logging</groupId>
-      <artifactId>commons-logging</artifactId>
-      <version>1.0.3</version>
-    </dependency>
-    <dependency>
-      <groupId>org.springframework</groupId>
-      <artifactId>spring-core</artifactId>
-      <version>2.5.4</version>
-    </dependency>
-    <dependency>
-      <groupId>org.springframework</groupId>
-      <artifactId>spring-hibernate3</artifactId>
-      <version>2.0.8</version>
-      <exclusions>
-        <exclusion>
-          <groupId>javax.transaction</groupId>
-          <artifactId>jta</artifactId>
-        </exclusion>
-      </exclusions>
-    </dependency>
-    <dependency>
-        <groupId>xmlrpc</groupId>
-        <artifactId>xmlrpc</artifactId>
-        <version>2.0.1</version>
-    </dependency>
-    <dependency>
-      <groupId>junit</groupId>
-      <artifactId>junit</artifactId>
-      <version>3.8.2</version>
-    </dependency>
-    <dependency>
-        <groupId>xerces</groupId>
-        <artifactId>xercesImpl</artifactId>
-        <version>2.9.1</version>
-    </dependency>
-  </dependencies>
 </project>


[05/14] oodt git commit: - fix compilation errors

Posted by ma...@apache.org.
- fix compilation errors

Project: http://git-wip-us.apache.org/repos/asf/oodt/repo
Commit: http://git-wip-us.apache.org/repos/asf/oodt/commit/038fdca6
Tree: http://git-wip-us.apache.org/repos/asf/oodt/tree/038fdca6
Diff: http://git-wip-us.apache.org/repos/asf/oodt/diff/038fdca6

Branch: refs/heads/development
Commit: 038fdca69310c46c9e4dfc22241a5a97f3e6450c
Parents: f8e7d95
Author: Chris Mattmann <ch...@jpl.nasa.gov>
Authored: Fri Oct 13 23:08:52 2017 -0700
Committer: Chris Mattmann <ch...@jpl.nasa.gov>
Committed: Fri Oct 13 23:08:52 2017 -0700

----------------------------------------------------------------------
 .../java/org/apache/oodt/commons/AvroExecServer.java | 15 +++++----------
 1 file changed, 5 insertions(+), 10 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/oodt/blob/038fdca6/commons/src/main/java/org/apache/oodt/commons/AvroExecServer.java
----------------------------------------------------------------------
diff --git a/commons/src/main/java/org/apache/oodt/commons/AvroExecServer.java b/commons/src/main/java/org/apache/oodt/commons/AvroExecServer.java
index 6aa5d40..eb1c786 100644
--- a/commons/src/main/java/org/apache/oodt/commons/AvroExecServer.java
+++ b/commons/src/main/java/org/apache/oodt/commons/AvroExecServer.java
@@ -122,15 +122,15 @@ public class AvroExecServer {
 
         // I should create avro interface to this server
 
-        Responder responder = new GenericResponder() {
+        /*Responder responder = new GenericResponder() {
             @Override
             public Object respond(Protocol.Message message, Object o) throws Exception {
 
                 return null;
             }
-        }
-        server =new HttpServer();
-        server.
+        }*/
+       /* server =new HttpServer();
+        server.*/
 
 //        xmlrpcServer = new XmlRpcServer();
 //        xmlrpcServer.addHandler("server", this);
@@ -191,10 +191,7 @@ public class AvroExecServer {
             } catch (IllegalAccessException ex) {
                 System.err.println("Initializer \"" + iname + "\" isn't public; aborting");
                 throw new EDAException(ex);
-            } catch (EDAException ex) {
-                System.err.println("Initializer \"" + iname + "\" failed: " + ex.getMessage());
-                throw new EDAException(ex);
-            }
+            } 
         }
     }
 
@@ -276,8 +273,6 @@ public class AvroExecServer {
         } catch (SAXException ex) {
             System.err.println("Error " + ex.getClass().getName() + " while attempting to parse the configuration"
                     + " file: " + ex.getMessage());
-        } catch (javax.naming.NamingException ex) {
-            System.err.println("Naming/directory error: " + ex.getClass().getName() + ": " + ex.getMessage());
         } catch (java.lang.reflect.InvocationTargetException ex) {
             Throwable target = ex.getTargetException();
             System.err.println("Constructor for \"" + className + "\" threw " + target.getClass().getName() + ": "


[13/14] oodt git commit: Fix for OODT-951: Wrong null checker contributed by JC.

Posted by ma...@apache.org.
Fix for OODT-951: Wrong null checker contributed by JC.


Project: http://git-wip-us.apache.org/repos/asf/oodt/repo
Commit: http://git-wip-us.apache.org/repos/asf/oodt/commit/3af750a5
Tree: http://git-wip-us.apache.org/repos/asf/oodt/tree/3af750a5
Diff: http://git-wip-us.apache.org/repos/asf/oodt/diff/3af750a5

Branch: refs/heads/development
Commit: 3af750a5c7c86f49ef1347d27cea089fe8a23d42
Parents: 9e5d75d
Author: Chris Mattmann <ch...@jpl.nasa.gov>
Authored: Sun Feb 25 18:28:45 2018 -0800
Committer: Chris Mattmann <ch...@jpl.nasa.gov>
Committed: Sun Feb 25 18:28:45 2018 -0800

----------------------------------------------------------------------
 CHANGES.txt                                                        | 2 ++
 .../cas/workflow/engine/PrioritizedQueueBasedWorkflowEngine.java   | 2 +-
 2 files changed, 3 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/oodt/blob/3af750a5/CHANGES.txt
----------------------------------------------------------------------
diff --git a/CHANGES.txt b/CHANGES.txt
index 5323db1..88ed8d1 100644
--- a/CHANGES.txt
+++ b/CHANGES.txt
@@ -4,6 +4,8 @@ Apache OODT Change Log
 =======
 Release 1.9 - In Progress
 
+* OODT-951 Wrong null checker (JC via mattmann)
+
 * OODT-972 Add filemgr.server and filemgr.client configuration keys to Radix filemgr.properties (lewismc via mattmann)
 
 * OODT-964, OODT-963 Fix issues merging Distributed ZK Config module into Avro-RPC branch (imesha,mattmann)

http://git-wip-us.apache.org/repos/asf/oodt/blob/3af750a5/workflow/src/main/java/org/apache/oodt/cas/workflow/engine/PrioritizedQueueBasedWorkflowEngine.java
----------------------------------------------------------------------
diff --git a/workflow/src/main/java/org/apache/oodt/cas/workflow/engine/PrioritizedQueueBasedWorkflowEngine.java b/workflow/src/main/java/org/apache/oodt/cas/workflow/engine/PrioritizedQueueBasedWorkflowEngine.java
index 315f3b9..6a1ef7f 100644
--- a/workflow/src/main/java/org/apache/oodt/cas/workflow/engine/PrioritizedQueueBasedWorkflowEngine.java
+++ b/workflow/src/main/java/org/apache/oodt/cas/workflow/engine/PrioritizedQueueBasedWorkflowEngine.java
@@ -70,7 +70,7 @@ public class PrioritizedQueueBasedWorkflowEngine implements WorkflowEngine {
       PrioritySorter prioritizer, WorkflowLifecycleManager lifecycle,
       EngineRunner runner, WorkflowRepository modelRepo, long querierWaitSeconds) {
     this.repo = repo;
-    this.prioritizer = prioritizer != null ? new HighestFIFOPrioritySorter(1,
+    this.prioritizer = prioritizer == null ? new HighestFIFOPrioritySorter(1,
         50, 1) : prioritizer;
     this.lifecycle = lifecycle;
     this.modelRepo = modelRepo;


[06/14] oodt git commit: Merge branch 'development'

Posted by ma...@apache.org.
Merge branch 'development'


Project: http://git-wip-us.apache.org/repos/asf/oodt/repo
Commit: http://git-wip-us.apache.org/repos/asf/oodt/commit/df9bdc2d
Tree: http://git-wip-us.apache.org/repos/asf/oodt/tree/df9bdc2d
Diff: http://git-wip-us.apache.org/repos/asf/oodt/diff/df9bdc2d

Branch: refs/heads/development
Commit: df9bdc2d8537ef1fb777bffbcee584815c2c0fe2
Parents: 038fdca bfb78c9
Author: Chris Mattmann <ch...@jpl.nasa.gov>
Authored: Sun Oct 15 13:53:32 2017 -0700
Committer: Chris Mattmann <ch...@jpl.nasa.gov>
Committed: Sun Oct 15 13:53:32 2017 -0700

----------------------------------------------------------------------
 .../oodt/cas/filemgr/ingest/TestRmiCache.java   |   2 +
 .../apache/oodt/pcs/tools/PCSHealthMonitor.java |  24 +-
 resource/pom.xml                                | 186 +++++---
 resource/src/main/avro/types/AvroJob.avsc       |  17 +
 resource/src/main/avro/types/AvroJobInput.avsc  |  11 +
 .../main/avro/types/AvroNameValueJobInput.avsc  |  10 +
 .../src/main/avro/types/AvroResourceNode.avsc   |  11 +
 .../src/main/avro/types/batchmgr_protocol.avdl  |  29 ++
 .../avro/types/resource_manager_protocol.avdl   |  53 +++
 .../cas/resource/batchmgr/AvroRpcBatchMgr.java  | 201 +++++++++
 .../batchmgr/AvroRpcBatchMgrFactory.java        |  32 ++
 .../resource/batchmgr/AvroRpcBatchMgrProxy.java | 136 ++++++
 .../cas/resource/structs/AvroTypeFactory.java   | 168 ++++++++
 .../cas/resource/structs/NameValueJobInput.java |   5 +-
 .../resource/system/AvroRpcResourceManager.java | 425 +++++++++++++++++++
 .../system/AvroRpcResourceManagerClient.java    | 305 +++++++++++++
 .../cas/resource/system/ResourceManager.java    |  31 ++
 .../resource/system/ResourceManagerClient.java  |  80 ++++
 .../system/XmlRpcResourceManagerClient.java     |  26 +-
 .../system/extern/AvroRpcBatchStub.java         | 230 ++++++++++
 .../cas/resource/batchmgr/TestBatchMgr.java     |  66 +++
 .../resource/structs/TestAvroTypeFactory.java   | 113 +++++
 .../system/TestAvroRpcResourceManager.java      | 162 +++++++
 .../system/TestXmlRpcResourceManager.java       |   4 +
 24 files changed, 2255 insertions(+), 72 deletions(-)
----------------------------------------------------------------------



[08/14] oodt git commit: Resolve merge conflicts.

Posted by ma...@apache.org.
Resolve merge conflicts.


Project: http://git-wip-us.apache.org/repos/asf/oodt/repo
Commit: http://git-wip-us.apache.org/repos/asf/oodt/commit/241c1dae
Tree: http://git-wip-us.apache.org/repos/asf/oodt/tree/241c1dae
Diff: http://git-wip-us.apache.org/repos/asf/oodt/diff/241c1dae

Branch: refs/heads/development
Commit: 241c1dae73747140067c1affa20e8c1ca0c5ed56
Parents: 9f48fea
Author: Chris Mattmann <ch...@jpl.nasa.gov>
Authored: Fri Nov 10 17:51:28 2017 -0800
Committer: Chris Mattmann <ch...@jpl.nasa.gov>
Committed: Sun Feb 4 09:49:58 2018 -0800

----------------------------------------------------------------------
 CHANGES.txt | 10 ++++++++--
 1 file changed, 8 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/oodt/blob/241c1dae/CHANGES.txt
----------------------------------------------------------------------
diff --git a/CHANGES.txt b/CHANGES.txt
index 4e50f80..e9861c5 100644
--- a/CHANGES.txt
+++ b/CHANGES.txt
@@ -9,10 +9,16 @@ Release 1.3 - In Progress
 * OODT-958 Update commons-collections
 * OODT-959 Update tika to 1.16
 
+=======
+Release 1.2.1 - 11/10/2017
+
+* OODT-967 Solr version for 1.2.1 breaks SolrDumper in File Manager (mattmann)
+
 Release 1.2 - 08/14/2017
 
-* OODT-955 Fix numhits error in Lucene Catalog
-* OODT-956 Add connection checks to components
+* OODT-955 Fix numhits error in Lucene Catalog (magicaltrout) 
+
+* OODT-956 Add connection checks to components (magicaltrout) 
 
 Release 1.1 - 07/18/2017
 


[10/14] oodt git commit: OODT-972 Add filemgr.server and filemgr.client configuration keys to Radix filemgr.properties

Posted by ma...@apache.org.
OODT-972 Add filemgr.server and filemgr.client configuration keys to Radix filemgr.properties


Project: http://git-wip-us.apache.org/repos/asf/oodt/repo
Commit: http://git-wip-us.apache.org/repos/asf/oodt/commit/73e8e853
Tree: http://git-wip-us.apache.org/repos/asf/oodt/tree/73e8e853
Diff: http://git-wip-us.apache.org/repos/asf/oodt/diff/73e8e853

Branch: refs/heads/development
Commit: 73e8e853d88e9b3fcb34a5d8f3b7f1c4aeba10ac
Parents: 13d4176
Author: Lewis John McGibbney <le...@gmail.com>
Authored: Thu Feb 22 21:28:29 2018 -0800
Committer: Lewis John McGibbney <le...@gmail.com>
Committed: Thu Feb 22 21:28:29 2018 -0800

----------------------------------------------------------------------
 .../filemgr/src/main/resources/etc/filemgr.properties         | 7 +++++++
 1 file changed, 7 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/oodt/blob/73e8e853/mvn/archetypes/radix/src/main/resources/archetype-resources/filemgr/src/main/resources/etc/filemgr.properties
----------------------------------------------------------------------
diff --git a/mvn/archetypes/radix/src/main/resources/archetype-resources/filemgr/src/main/resources/etc/filemgr.properties b/mvn/archetypes/radix/src/main/resources/archetype-resources/filemgr/src/main/resources/etc/filemgr.properties
index acbfe57..a48feef 100644
--- a/mvn/archetypes/radix/src/main/resources/archetype-resources/filemgr/src/main/resources/etc/filemgr.properties
+++ b/mvn/archetypes/radix/src/main/resources/archetype-resources/filemgr/src/main/resources/etc/filemgr.properties
@@ -18,6 +18,13 @@
 # repository factory
 filemgr.repository.factory=org.apache.oodt.cas.filemgr.repository.XMLRepositoryManagerFactory
 
+# RPC implementation, options include the deprecated XMLRPC or the preferred AvroRPC
+# uncomment the Avro implementations to use AvroRPC
+filemgr.server=org.apache.oodt.cas.filemgr.system.rpc.XmlRpcFileManagerServerFactory
+filemgr.client=org.apache.oodt.cas.filemgr.system.rpc.XmlRpcFileManagerClientFactory
+#filemgr.server=org.apache.oodt.cas.filemgr.system.rpc.AvroFileManagerServerFactory
+#filemgr.client=org.apache.oodt.cas.filemgr.system.rpc.AvroFileManagerClientFactory
+
 # Lucene catalog factory
 filemgr.catalog.factory=org.apache.oodt.cas.filemgr.catalog.LuceneCatalogFactory
 


[03/14] oodt git commit: Resolve conflicts again.

Posted by ma...@apache.org.
Resolve conflicts again.


Project: http://git-wip-us.apache.org/repos/asf/oodt/repo
Commit: http://git-wip-us.apache.org/repos/asf/oodt/commit/55b0f001
Tree: http://git-wip-us.apache.org/repos/asf/oodt/tree/55b0f001
Diff: http://git-wip-us.apache.org/repos/asf/oodt/diff/55b0f001

Branch: refs/heads/development
Commit: 55b0f0014327f529803dc2c734a32710befe8481
Parents: 401f241
Author: Chris Mattmann <ch...@jpl.nasa.gov>
Authored: Fri Oct 13 22:51:39 2017 -0700
Committer: Chris Mattmann <ch...@jpl.nasa.gov>
Committed: Fri Oct 13 22:51:39 2017 -0700

----------------------------------------------------------------------
 commons/pom.xml | 3 ---
 1 file changed, 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/oodt/blob/55b0f001/commons/pom.xml
----------------------------------------------------------------------
diff --git a/commons/pom.xml b/commons/pom.xml
index cf54eba..5054be3 100644
--- a/commons/pom.xml
+++ b/commons/pom.xml
@@ -177,10 +177,7 @@
       </build>
     </profile>
   </profiles>
-<<<<<<< HEAD
-=======
   <dependencies>
-
     <dependency>
       <groupId>org.apache.avro</groupId>
       <artifactId>avro</artifactId>


[14/14] oodt git commit: Merge branch 'development' of https://git-wip-us.apache.org/repos/asf/oodt into development

Posted by ma...@apache.org.
Merge branch 'development' of https://git-wip-us.apache.org/repos/asf/oodt into development


Project: http://git-wip-us.apache.org/repos/asf/oodt/repo
Commit: http://git-wip-us.apache.org/repos/asf/oodt/commit/d63616bb
Tree: http://git-wip-us.apache.org/repos/asf/oodt/tree/d63616bb
Diff: http://git-wip-us.apache.org/repos/asf/oodt/diff/d63616bb

Branch: refs/heads/development
Commit: d63616bbaa13cf9a404325159da7b28d99f94f61
Parents: 3af750a 75d292c
Author: Chris Mattmann <ch...@jpl.nasa.gov>
Authored: Mon Feb 26 20:20:56 2018 -0800
Committer: Chris Mattmann <ch...@jpl.nasa.gov>
Committed: Mon Feb 26 20:20:56 2018 -0800

----------------------------------------------------------------------
 CHANGES.txt                                     |   1 +
 .../oodt/cas/filemgr/catalog/LuceneCatalog.java |  24 +-
 .../filemgr/system/AvroFileManagerClient.java   | 320 +++++++++++++++++--
 3 files changed, 314 insertions(+), 31 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/oodt/blob/d63616bb/CHANGES.txt
----------------------------------------------------------------------
diff --cc CHANGES.txt
index 88ed8d1,9627d2f..2060302
--- a/CHANGES.txt
+++ b/CHANGES.txt
@@@ -2,36 -2,18 +2,37 @@@ Apache OODT Change Lo
  ======================
  
  =======
 -Release 1.3 - In Progress
 +Release 1.9 - In Progress
 +
 +* OODT-951 Wrong null checker (JC via mattmann)
 +
 +* OODT-972 Add filemgr.server and filemgr.client configuration keys to Radix filemgr.properties (lewismc via mattmann)
  
  * OODT-964, OODT-963 Fix issues merging Distributed ZK Config module into Avro-RPC branch (imesha,mattmann)
 +
  * OODT-957 Add CVE reporting plugin to maven build chain
 +
  * OODT-958 Update commons-collections
 +
  * OODT-959 Update tika to 1.16
+ * OODT-968 Add metadata removes product
  
 +=======
 +Release 1.2.2 - 02/05/2018
 +
 +* OODT-968 Add metadata removes product
 +
 +
 +=======
 +Release 1.2.1 - 11/10/2017
 +
 +* OODT-967 Solr version for 1.2.1 breaks SolrDumper in File Manager (mattmann)
 +
  Release 1.2 - 08/14/2017
  
 -* OODT-955 Fix numhits error in Lucene Catalog
 -* OODT-956 Add connection checks to components
 +* OODT-955 Fix numhits error in Lucene Catalog (magicaltrout) 
 +
 +* OODT-956 Add connection checks to components (magicaltrout) 
  
  Release 1.1 - 07/18/2017
  


[09/14] oodt git commit: Fix for OODT-967 Solr version for 1.2.1 breaks SolrDumper in File Manager

Posted by ma...@apache.org.
Fix for OODT-967 Solr version for 1.2.1 breaks SolrDumper in File Manager


Project: http://git-wip-us.apache.org/repos/asf/oodt/repo
Commit: http://git-wip-us.apache.org/repos/asf/oodt/commit/13d41767
Tree: http://git-wip-us.apache.org/repos/asf/oodt/tree/13d41767
Diff: http://git-wip-us.apache.org/repos/asf/oodt/diff/13d41767

Branch: refs/heads/development
Commit: 13d41767ad333f426edef342ad083171b5f88643
Parents: 241c1da
Author: Chris Mattmann <ch...@jpl.nasa.gov>
Authored: Fri Nov 10 17:51:28 2017 -0800
Committer: Chris Mattmann <ch...@jpl.nasa.gov>
Committed: Sun Feb 4 09:56:06 2018 -0800

----------------------------------------------------------------------

----------------------------------------------------------------------