You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@uima.apache.org by cw...@apache.org on 2013/01/02 23:13:04 UTC

svn commit: r1428087 [4/4] - in /uima/sandbox/uima-ducc/trunk/src/main: ./ admin/ assembly/ config/ resources/ saxon/ scripts/

Propchange: uima/sandbox/uima-ducc/trunk/src/main/scripts/dd2spring.xsl
------------------------------------------------------------------------------
    svn:eol-style = native

Added: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_boot.py
URL: http://svn.apache.org/viewvc/uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_boot.py?rev=1428087&view=auto
==============================================================================
--- uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_boot.py (added)
+++ uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_boot.py Wed Jan  2 22:13:03 2013
@@ -0,0 +1,38 @@
+#! /usr/bin/env python
+
+# -----------------------------------------------------------------------
+# 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.
+# -----------------------------------------------------------------------
+
+import os
+import sys
+
+# simple bootstratp to establish DUCC_HOME and to set the python path so it can
+# find the common code in DUCC_HOME/admin
+def set_ducc_home():
+    if ( os.environ.has_key('DUCC_HOME') ):
+        DUCC_HOME = os.environ['DUCC_HOME']
+    else:
+        me = os.path.abspath(sys.argv[0])    
+        ndx = me.rindex('/')
+        ndx = me.rindex('/', 0, ndx)
+        DUCC_HOME = me[:ndx]          # split from 0 to ndx
+        os.environ['DUCC_HOME'] = DUCC_HOME
+
+    sys.path.append(DUCC_HOME + '/admin')
+

Propchange: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_boot.py
------------------------------------------------------------------------------
    svn:eol-style = native

Added: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_cancel
URL: http://svn.apache.org/viewvc/uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_cancel?rev=1428087&view=auto
==============================================================================
--- uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_cancel (added)
+++ uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_cancel Wed Jan  2 22:13:03 2013
@@ -0,0 +1,35 @@
+#! /usr/bin/env python
+# -----------------------------------------------------------------------
+# 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.
+# -----------------------------------------------------------------------
+
+
+from ducc_boot import *
+set_ducc_home()
+
+from ducc_util import DuccUtil
+
+class DuccCancel(DuccUtil):
+
+    def main(self, argv):
+        self.spawn(self.java(), '-jar', self.DUCC_HOME + '/lib/ducc-cancel.jar', ' '.join(argv))
+
+if __name__ == "__main__":
+    cancel = DuccCancel()
+    cancel.main(sys.argv[1:])
+

Added: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_cancel.py
URL: http://svn.apache.org/viewvc/uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_cancel.py?rev=1428087&view=auto
==============================================================================
--- uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_cancel.py (added)
+++ uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_cancel.py Wed Jan  2 22:13:03 2013
@@ -0,0 +1,32 @@
+# -----------------------------------------------------------------------
+# 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.
+# -----------------------------------------------------------------------
+
+'''
+Created on Jan 12, 2012
+'''
+
+import sys
+
+from ducc_iface import DuccIface
+
+if __name__ == "__main__":
+    jclass = "org.apache.uima.ducc.cli.DuccJobCancel"
+    pclass = sys.argv[0]
+    ducc = DuccIface()
+    ducc.main(sys.argv[1:],pclass,jclass)

Propchange: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_cancel.py
------------------------------------------------------------------------------
    svn:eol-style = native

Added: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_iface.py
URL: http://svn.apache.org/viewvc/uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_iface.py?rev=1428087&view=auto
==============================================================================
--- uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_iface.py (added)
+++ uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_iface.py Wed Jan  2 22:13:03 2013
@@ -0,0 +1,141 @@
+#! /usr/bin/env python
+# -----------------------------------------------------------------------
+# 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.
+# -----------------------------------------------------------------------
+
+'''
+Created on Sep 28, 2011
+'''
+    
+import os
+import sys
+import subprocess
+
+class DuccIface:
+    
+    def cpAppend(self,cp,append):
+        if( self.debug ):
+            print "append="+append
+        if ( cp == "" ):
+            return append   
+        
+        else:
+            return cp+":"+ append
+                            
+    def addJarsOpen1(self,cp,lib):
+        for libdir in self.libdirs1:
+            pathdir = os.path.join(lib,libdir)
+            for libfile in os.listdir(pathdir):
+                if ( libfile.endswith(".jar") ):
+                    pathjar = os.path.join(pathdir,libfile)
+                    cp = self.cpAppend(cp,pathjar)
+        return cp
+
+    def addJarsDucc(self,cp,lib):
+        for jar in self.duccjars:
+            pathjar = os.path.join(lib,jar)
+            cp = self.cpAppend(cp,pathjar)
+        return cp 
+    
+    def __init__(self):
+        return
+    
+    def initialize(self):
+        
+        self.debug = False
+        
+        self.jproperties = "-Dducc.deploy.configuration=resources/ducc.properties"
+
+        self.duccjars = [
+                    "ducc-agent.jar",
+                    "ducc-cli.jar", 
+                    "ducc-common.jar",
+                    "ducc-jd.jar",
+                    "ducc-orchestrator.jar",
+                    "ducc-pm.jar",
+                    "ducc-rm.jar",
+                    "ducc-sm.jar",
+                    "ducc-web.jar", 
+                    ]
+
+        self.libdirs1 = [ 
+                   "apache-activemq-5.5.0",
+                   "apache-commons-cli-1.2",
+                   "apache-commons-lang-2.6",
+                   "guava-r09",
+                   "apache-log4j-1.2.16",
+                   "uima-as.2.3.1",
+                   "apache-camel-2.7.1",
+                   "apache-commons-collections-3.2.1",
+                   "joda-time-1.6",
+                   "springframework-3.0.5",
+                   "xmlbeans-2.5.0",
+                   "bluepages",
+                   ]
+                    
+        ducc_home = os.environ.get("DUCC_HOME", "")
+        
+        self.lib = os.path.join(ducc_home,"lib")
+        if ( self.debug ):
+            print "LIB="+self.lib
+        
+        self.cp = ""
+        self.cp = self.addJarsDucc(self.cp,self.lib)
+        self.cp = self.addJarsOpen1(self.cp,self.lib)
+        self.cp = self.cpAppend(self.cp,os.path.join(ducc_home,"resources"))
+        if ( self.debug ):
+            print "CLASSPATH="+self.cp
+        
+        return
+    
+    def main(self,argv,pclass,jclass):
+        ducc_home = os.environ.get("DUCC_HOME", "")
+        if(ducc_home == ""):
+            print "DUCC_HOME not set in environment"
+            sys.exit(1)
+        jvm_dir = os.environ.get("JVM_DIR", "")
+
+        if(jvm_dir == ""):
+            jvm_dir = os.environ.get("JAVA_HOME", "")
+            if ( jvm_dir == "" ):
+                print 'JAVA_HOME is not set in the environment'
+                sys.exit(1)
+            else:
+                jvm = jvm_dir + os.sep + '/bin/java'
+        else:
+            jvm = jvm_dir + os.sep + 'java'
+
+
+        self.initialize()
+        jcmd = "-classpath "+self.cp+" "+self.jproperties+" "+jclass
+        jcmdargs = ""
+        for arg in argv:
+            jcmdargs += " "+arg
+        cmd = jvm+" "+jcmd+" "+jcmdargs
+        if(self.debug):
+            print cmd
+        
+        process = subprocess.Popen(cmd, shell=True, close_fds=True, stdout=subprocess.PIPE, stderr=subprocess.PIPE)
+        
+        stdout, stderr = process.communicate()
+
+        print stdout
+        if stderr != "":
+            print stderr
+
+        return

Propchange: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_iface.py
------------------------------------------------------------------------------
    svn:eol-style = native

Added: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_monitor
URL: http://svn.apache.org/viewvc/uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_monitor?rev=1428087&view=auto
==============================================================================
--- uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_monitor (added)
+++ uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_monitor Wed Jan  2 22:13:03 2013
@@ -0,0 +1,34 @@
+#! /usr/bin/env python
+# -----------------------------------------------------------------------
+# 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.
+# -----------------------------------------------------------------------
+
+ 
+from ducc_boot import *
+set_ducc_home()
+
+from ducc_util import DuccUtil
+
+class DuccMonitor(DuccUtil):
+
+    def main(self, argv):
+        self.spawn(self.java(), '-jar', self.DUCC_HOME +  '/lib/ducc-monitor.jar', ' '.join(argv))
+
+if __name__ == "__main__":
+    mon = DuccMonitor()
+    mon.main(sys.argv[1:])

Added: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_monitor.py
URL: http://svn.apache.org/viewvc/uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_monitor.py?rev=1428087&view=auto
==============================================================================
--- uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_monitor.py (added)
+++ uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_monitor.py Wed Jan  2 22:13:03 2013
@@ -0,0 +1,32 @@
+# -----------------------------------------------------------------------
+# 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.
+# -----------------------------------------------------------------------
+
+'''
+Created on Jan 12, 2012
+'''
+
+import sys
+
+from ducc_iface import DuccIface
+
+if __name__ == "__main__":
+    jclass = "org.apache.uima.ducc.cli.DuccJobMonitor"
+    pclass = sys.argv[0]
+    ducc = DuccIface()
+    ducc.main(sys.argv[1:],pclass,jclass)

Propchange: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_monitor.py
------------------------------------------------------------------------------
    svn:eol-style = native

Added: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_perf_stats
URL: http://svn.apache.org/viewvc/uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_perf_stats?rev=1428087&view=auto
==============================================================================
--- uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_perf_stats (added)
+++ uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_perf_stats Wed Jan  2 22:13:03 2013
@@ -0,0 +1,35 @@
+#! /usr/bin/env python
+# -----------------------------------------------------------------------
+# 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.
+# -----------------------------------------------------------------------
+
+
+from ducc_boot import *
+set_ducc_home()
+
+from ducc_util import DuccUtil
+
+class DuccPerfStats(DuccUtil):
+
+    def main(self, argv):
+        self.spawn(self.java(), '-jar', self.DUCC_HOME + '/lib/ducc-perf-stats.jar', ' '.join(argv))
+
+if __name__ == "__main__":
+    cancel = DuccPerfStats()
+    cancel.main(sys.argv[1:])
+

Added: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_qmon
URL: http://svn.apache.org/viewvc/uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_qmon?rev=1428087&view=auto
==============================================================================
--- uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_qmon (added)
+++ uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_qmon Wed Jan  2 22:13:03 2013
@@ -0,0 +1,110 @@
+#! /usr/bin/env python
+
+# -----------------------------------------------------------------------
+# 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.
+# -----------------------------------------------------------------------
+
+from ducc_boot import *
+import getopt
+
+set_ducc_home()
+
+from ducc_util import DuccUtil
+
+
+class DuccQmon(DuccUtil):
+        
+    def usage(self, *msg):
+        if ( msg[0] != None ):
+            print ' '.join(msg)
+
+        print 'Usage:'
+        print '   ducc_qmon [options]'
+        print ''
+        print 'Options:'
+        print '    -j --job jobid'
+        print '          Monitor the UIMA-AS queue for the indicated job'
+        print ''
+        print '    -q --queue queue-name'
+        print '         Monitor the indicated UIMA-AS queue.  Both broker and port options must also be given'
+        print ''
+        print '    -b --broker broker-host'
+        print '         Specifies the host where the broker to monitor is.  Only valid with -q and -p'
+        print ''
+        print '    -p --port broker-port'
+        print '         Specifies the port for the broker to monitor.  Only valid with -q and -b'
+        print ''
+        print 'Examples:'
+        print ''
+        print '    Monitor the UIMA-AS queue for DUCC job 23:'
+        print '       ducc_qmon -j 23'
+        print ''
+        print '    Monitor the UIMA-AS queue for some service:'
+        print '       ducc_mon -q RandomSleepTest -b bluej291 -p 1099'        
+        sys.exit(1)
+
+
+    def main(self, argv):
+
+        jobid = None
+        broker_host = None
+        broker_port = None
+        queue = None
+
+        if ( len(argv) == 0 ):
+            self.usage(None);
+
+        try:
+            opts, args = getopt.getopt(argv, 'b:j:p:q:h?v', ['broker=', 'job=', 'port=', 'queue=', 'help=', 'version'])
+        except:
+            self.usage('Invalid arguments', ' '.join(argv))
+                       
+        for ( o, a ) in opts:
+            if o in ( '-j', '--job' ): 
+                jobid = a
+            elif o in ( '-b', '--broker' ):
+                broker_host = a
+            elif o in ( '-p', '--port'):
+                broker_port = a
+            elif o in ('-q', '--queue'):
+                queue = a
+            elif o in ('-h', '-?', '--help'):
+                self.usage(None);
+            else:
+                self.invalid('Invalid arguments: ', ' '.join(argv))
+
+        if ( jobid != None ):
+            if ( (broker_host != None ) or (broker_port != None) or (queue != None) ) : 
+                self.invalid('Job id is mutually exclusive with broker, port, and queue')
+            else:
+                queue = 'ducc.jd.queue.' + jobid
+                self.spawn(self.java(), '-jar', self.DUCC_HOME + '/lib/ducc-qmon.jar',  queue, self.broker_host, self.broker_jmx_port)
+                return
+
+        if ( broker_host == None ):
+            broker_host = self.broker_host
+        if ( broker_port == None ):
+            broker_port = self.broker_jmx_port
+
+        self.spawn(self.java(), '-jar', self.DUCC_HOME + '/lib/ducc-qmon.jar',  queue, broker_host, broker_port)
+
+
+if __name__ == "__main__":
+    svc = DuccQmon()
+    svc.main(sys.argv[1:])
+

Added: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_reserve
URL: http://svn.apache.org/viewvc/uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_reserve?rev=1428087&view=auto
==============================================================================
--- uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_reserve (added)
+++ uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_reserve Wed Jan  2 22:13:03 2013
@@ -0,0 +1,35 @@
+#! /usr/bin/env python
+
+# -----------------------------------------------------------------------
+# 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.
+# -----------------------------------------------------------------------
+
+
+from ducc_boot import *
+set_ducc_home()
+
+from ducc_util import DuccUtil
+
+class DuccReserve(DuccUtil):
+
+    def main(self, argv):
+        self.spawn(self.java(), '-jar',  self.DUCC_HOME + '/lib/ducc-reserve.jar', ' '.join(argv))
+
+if __name__ == "__main__":
+    res = DuccReserve()
+    res.main(sys.argv[1:])

Added: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_reserve.py
URL: http://svn.apache.org/viewvc/uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_reserve.py?rev=1428087&view=auto
==============================================================================
--- uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_reserve.py (added)
+++ uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_reserve.py Wed Jan  2 22:13:03 2013
@@ -0,0 +1,32 @@
+# -----------------------------------------------------------------------
+# 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.
+# -----------------------------------------------------------------------
+
+'''
+Created on Jan 12, 2012
+'''
+
+import sys
+
+from ducc_iface import DuccIface
+
+if __name__ == "__main__":
+    jclass = "org.apache.uima.ducc.cli.DuccReservationSubmit"
+    pclass = sys.argv[0]
+    ducc = DuccIface()
+    ducc.main(sys.argv[1:],pclass,jclass)

Propchange: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_reserve.py
------------------------------------------------------------------------------
    svn:eol-style = native

Added: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_service_cancel
URL: http://svn.apache.org/viewvc/uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_service_cancel?rev=1428087&view=auto
==============================================================================
--- uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_service_cancel (added)
+++ uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_service_cancel Wed Jan  2 22:13:03 2013
@@ -0,0 +1,36 @@
+#! /usr/bin/env python
+
+# -----------------------------------------------------------------------
+# 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.
+# -----------------------------------------------------------------------
+
+
+from ducc_boot import *
+set_ducc_home()
+
+from ducc_util import DuccUtil
+
+class DuccServiceCancel(DuccUtil):
+
+    def main(self, argv):
+        self.spawn(self.java(), '-jar', self.DUCC_HOME +  '/lib/ducc-service-cancel.jar', ' '.join(argv))
+
+if __name__ == "__main__":
+    cancel = DuccServiceCancel()
+    cancel.main(sys.argv[1:])
+

Added: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_service_submit
URL: http://svn.apache.org/viewvc/uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_service_submit?rev=1428087&view=auto
==============================================================================
--- uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_service_submit (added)
+++ uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_service_submit Wed Jan  2 22:13:03 2013
@@ -0,0 +1,41 @@
+#! /usr/bin/env python
+
+# -----------------------------------------------------------------------
+# 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.
+# -----------------------------------------------------------------------
+
+
+import sys
+import os
+
+from ducc_boot import *
+set_ducc_home()
+
+from ducc_util import DuccUtil
+
+class DuccServiceSubmit(DuccUtil):
+
+    def main(self, argv):
+        self.spawn(self.java(), '-jar', self.DUCC_HOME + '/lib/ducc-service-submit.jar', ' '.join(argv))
+
+if __name__ == "__main__":
+    submit = DuccServiceSubmit()
+    #for i in os.environ['CLASSPATH'].split(':'):
+    #    print i
+
+    submit.main(sys.argv[1:])

Added: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_services
URL: http://svn.apache.org/viewvc/uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_services?rev=1428087&view=auto
==============================================================================
--- uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_services (added)
+++ uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_services Wed Jan  2 22:13:03 2013
@@ -0,0 +1,48 @@
+#! /usr/bin/env python
+
+# -----------------------------------------------------------------------
+# 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.
+# -----------------------------------------------------------------------
+
+
+from ducc_boot import *
+import getopt
+
+set_ducc_home()
+
+from ducc_util import DuccUtil
+
+class DuccServices(DuccUtil):
+
+    def main(self, argv):
+        
+        if ( len(argv) > 0 ):
+            if ( argv[0] == '--submit' ):
+                self.spawn(self.java(), '-jar', self.DUCC_HOME + '/lib/ducc-service-submit.jar', ' '.join(argv[1:]))
+                return
+
+            if ( argv[0] == '--cancel' ):
+                self.spawn(self.java(), '-jar', self.DUCC_HOME + '/lib/ducc-service-cancel.jar', ' '.join(argv[1:]))
+                return
+
+        self.spawn(self.java(), '-jar', self.DUCC_HOME + '/lib/ducc-services.jar', ' '.join(argv))
+
+if __name__ == "__main__":
+    svc = DuccServices()
+    svc.main(sys.argv[1:])
+

Added: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_submit
URL: http://svn.apache.org/viewvc/uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_submit?rev=1428087&view=auto
==============================================================================
--- uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_submit (added)
+++ uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_submit Wed Jan  2 22:13:03 2013
@@ -0,0 +1,38 @@
+#! /usr/bin/env python
+
+# -----------------------------------------------------------------------
+# 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.
+# -----------------------------------------------------------------------
+
+
+import sys
+import os
+
+from ducc_boot import *
+set_ducc_home()
+
+from ducc_util import DuccUtil
+
+class DuccSubmit(DuccUtil):
+
+    def main(self, argv):
+        self.spawn(self.java(), '-jar', self.DUCC_HOME + '/lib/ducc-submit.jar', ' '.join(argv))
+
+if __name__ == "__main__":
+    submit = DuccSubmit()
+    submit.main(sys.argv[1:])

Added: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_submit.py
URL: http://svn.apache.org/viewvc/uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_submit.py?rev=1428087&view=auto
==============================================================================
--- uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_submit.py (added)
+++ uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_submit.py Wed Jan  2 22:13:03 2013
@@ -0,0 +1,32 @@
+# -----------------------------------------------------------------------
+# 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.
+# -----------------------------------------------------------------------
+
+'''
+Created on Jan 12, 2012
+'''
+
+import sys
+
+from ducc_iface import DuccIface
+
+if __name__ == "__main__":
+    jclass = "org.apache.uima.ducc.cli.DuccJobSubmit"
+    pclass = sys.argv[0]
+    ducc = DuccIface()
+    ducc.main(sys.argv[1:],pclass,jclass)

Propchange: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_submit.py
------------------------------------------------------------------------------
    svn:eol-style = native

Added: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_unreserve
URL: http://svn.apache.org/viewvc/uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_unreserve?rev=1428087&view=auto
==============================================================================
--- uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_unreserve (added)
+++ uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_unreserve Wed Jan  2 22:13:03 2013
@@ -0,0 +1,35 @@
+#! /usr/bin/env python
+
+# -----------------------------------------------------------------------
+# 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.
+# -----------------------------------------------------------------------
+
+
+from ducc_boot import *
+set_ducc_home()
+
+from ducc_util import DuccUtil
+
+class DuccUnReserve(DuccUtil):
+
+    def main(self, argv):
+        self.spawn(self.java(), '-jar', self.DUCC_HOME + '/lib/ducc-unreserve.jar', ' '.join(argv))
+
+if __name__ == "__main__":
+    unres = DuccUnReserve()
+    unres.main(sys.argv[1:])

Added: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_unreserve.py
URL: http://svn.apache.org/viewvc/uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_unreserve.py?rev=1428087&view=auto
==============================================================================
--- uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_unreserve.py (added)
+++ uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_unreserve.py Wed Jan  2 22:13:03 2013
@@ -0,0 +1,32 @@
+# -----------------------------------------------------------------------
+# 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.
+# -----------------------------------------------------------------------
+
+'''
+Created on Jan 12, 2012
+'''
+
+import sys
+
+from ducc_iface import DuccIface
+
+if __name__ == "__main__":
+    jclass = "org.apache.uima.ducc.cli.DuccReservationCancel"
+    pclass = sys.argv[0]
+    ducc = DuccIface()
+    ducc.main(sys.argv[1:],pclass,jclass)

Propchange: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_unreserve.py
------------------------------------------------------------------------------
    svn:eol-style = native

Added: uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_viewperf
URL: http://svn.apache.org/viewvc/uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_viewperf?rev=1428087&view=auto
==============================================================================
--- uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_viewperf (added)
+++ uima/sandbox/uima-ducc/trunk/src/main/scripts/ducc_viewperf Wed Jan  2 22:13:03 2013
@@ -0,0 +1,36 @@
+#! /usr/bin/env python
+
+# -----------------------------------------------------------------------
+# 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.
+# -----------------------------------------------------------------------
+
+
+
+from ducc_boot import *
+set_ducc_home()
+
+from ducc_util import DuccUtil
+
+class DuccViewperf(DuccUtil):
+
+    def main(self, argv):
+        self.spawn(self.java(), '-jar', self.DUCC_HOME + '/lib/ducc-viewperf.jar', ' '.join(argv))
+
+if __name__ == "__main__":
+    perf = DuccViewperf()
+    perf.main(sys.argv[1:])