You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@tuscany.apache.org by ro...@apache.org on 2007/07/13 20:26:31 UTC

svn commit: r556089 [10/11] - in /incubator/tuscany/cpp/sca: VSExpress/tuscany_sca/tuscany_sca_cpp/ doc/ runtime/extensions/cpp/ runtime/extensions/cpp/tools/ runtime/extensions/cpp/tools/scagen/ runtime/extensions/cpp/tools/scagen/META-INF/ runtime/ex...

Added: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/DomNodeHandler.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/DomNodeHandler.java?view=auto&rev=556089
==============================================================================
--- incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/DomNodeHandler.java (added)
+++ incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/DomNodeHandler.java Fri Jul 13 11:26:14 2007
@@ -0,0 +1,46 @@
+/**
+ *
+ *  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.
+ */
+
+/* @version $Rev$ $Date$ */
+
+package org.apache.tuscany.sca.cpp.tools.services;
+
+import java.util.Map;
+
+import org.w3c.dom.Node;
+
+public interface DomNodeHandler {
+    
+    public static int ELEMENT = 1;
+    /**
+     * An interface for classes that can process DOM nodes.
+     * 
+     * @param node the DOM node being consumed
+     * @param contextXPath the XPath to this node 
+     * @param handlers The map from element name to node handler
+     * @param parameters A map of parameters - this is often used by a handler to place
+     * a name-value pair, the name is often an Xpath like representation of the
+     * location of the data in the DOM but handlers are free to use whatever 
+     * they like - the contextXpath is generated as an Xpath prefix for those
+     * handlers that wish to use it.  
+     */
+     void handleNode( Node node, String contextXPath, Map handlers, Map parameters );
+
+}

Propchange: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/DomNodeHandler.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/DomNodeHandler.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Added: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/GenericDomNodeHandler.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/GenericDomNodeHandler.java?view=auto&rev=556089
==============================================================================
--- incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/GenericDomNodeHandler.java (added)
+++ incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/GenericDomNodeHandler.java Fri Jul 13 11:26:14 2007
@@ -0,0 +1,220 @@
+/**
+ *
+ *  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.
+ */
+
+/* @version $Rev$ $Date$ */
+
+package org.apache.tuscany.sca.cpp.tools.services;
+
+import java.io.File;
+import java.util.Iterator;
+import java.util.Map;
+import java.util.Set;
+import java.util.Map.Entry;
+
+import org.apache.tuscany.sca.cpp.tools.common.Utils;
+import org.w3c.dom.NamedNodeMap;
+import org.w3c.dom.Node;
+import org.w3c.dom.NodeList;
+
+/**
+ * 
+ * 
+ * 
+ *  
+ */
+public class GenericDomNodeHandler implements DomNodeHandler {
+    /**
+     * This method parses the DOM attributes into name value pairs in the
+     * parameter map each valued keyed by its XPath.
+     * 
+     * @param node
+     *            the DOM node being processed
+     * @param contextPath
+     *            the XPath to the DOM node being processed
+     * @param parameters
+     *            a scratchpad map of name value pairs
+     */
+    public void transferAttrsToParameters(Node node, String contextPath,
+            Map parameters) {
+
+        if (node == null || contextPath == null || parameters == null)
+            return;
+
+        NamedNodeMap attrs = node.getAttributes();
+        if (attrs != null) {
+            for (int i = 0; i < attrs.getLength(); i++) {
+                Node attr = attrs.item(i);
+                parameters.put(contextPath + "/" + "@" + attr.getNodeName(),
+                        attr.getNodeValue());
+
+                // Report the library name to the deployment tool if required.
+                if ("library".equals(attr.getNodeName())) {
+                    //This is a path relative to the composite root.
+                    //so we need to add it in.
+                    File mod = (File) parameters.get("compositeOrFragmentFile");
+                    if (null != mod) {
+                        String separatorForRegex = File.separator.replaceAll(
+                                "\\\\", "\\\\\\\\");
+
+                        String end = attr.getNodeValue().replaceAll("[/\\\\]+",
+                                separatorForRegex);
+
+                        if (!end.startsWith(File.separator)) {
+                            end = File.separator + end;
+                        }
+
+                        String fullPath = mod.getParentFile().getAbsolutePath()
+                                + end;
+                        Utils.postEvent(Utils.DEPLOYMENT_ARTEFACT_ENCOUNTERED,
+                                fullPath);
+                    }
+
+                }
+
+            }
+        }
+        return;
+    }
+
+    /**
+     * This method will iterate through the DOM node's children and call the
+     * appropriate handler for each one.
+     * 
+     * @param node
+     *            the DOM node being processed
+     * @param contextPath
+     *            the XPath to the DOM node being processed
+     * @param handlers
+     *            a map of element name to handler objects
+     * @param parameters
+     *            a scratchpad map of name value pairs
+     */
+    public void handleChildElements(Node node, String contextPath,
+            Map handlers, Map parameters) {
+
+        if (node == null || contextPath == null)
+            return;
+
+        NodeList children = node.getChildNodes();
+        if (children != null) {
+            for (int i = 0; i < children.getLength(); i++) {
+                Node child = children.item(i);
+                mapNodeToHandlerAndHandle(child, contextPath + "/"
+                        + child.getNodeName(), handlers, parameters);
+            }
+        }
+        return;
+    }
+
+    /**
+     * This method will resolve any registered handler for a particular DOM
+     * element and call the handleNode method on it. If the handlers map has a
+     * mapping from "entity" to an instance of EntityHandler which implements
+     * the DomNodeHandler interface then any node that looks like <entity>
+     * <any_other/><stuff/></entity>
+     * 
+     * Will be passed to the EntityHandler to process.
+     * 
+     * @param node
+     *            the DOM node being processed
+     * @param contextPath
+     *            the XPath to the DOM node being processed
+     * @param handlers
+     *            a map of element name to handler objects
+     * @param parameters
+     *            a scratchpad map of name value pairs
+     */
+    public static void mapNodeToHandlerAndHandle(Node node, String contextPath,
+            Map handlers, Map parameters) {
+        if (node != null && node.getNodeType() == DomNodeHandler.ELEMENT) {
+            String nodeName = node.getNodeName();
+            if (nodeName != null && nodeName.length() > 0) {
+                DomNodeHandler handler = (DomNodeHandler) handlers
+                        .get(nodeName);
+                if (handler != null) {
+                    handler.handleNode(node, contextPath, handlers, parameters);
+                }
+            }
+        }
+    }
+
+    /**
+     * This method will place the attributes in this node into the parameter map
+     * keyed by the XPath and recursively continue processing for any
+     * sub-elements of the node.
+     * 
+     * @param node
+     *            The DOM node being consumed
+     * @param contextXPath
+     *            The XPath to this node
+     * @param handlers
+     *            The map from element name to node handler
+     * @param parameters
+     *            A map of parameters - this is often used by a handler to place
+     *            a name-value pair, the name is often an Xpath representation
+     *            of the location of the data in the DOM but handlers are free
+     *            to use whatever they like - the contextXpath is generated as
+     *            an Xpath prefix for those handlers that wish to use it.
+     */
+    public void handleNode(Node node, String contextXPath, Map handlers,
+            Map parameters) {
+
+        clearParametersAtThisXPath(contextXPath, parameters);
+        transferAttrsToParameters(node, contextXPath, parameters);
+        handleChildElements(node, contextXPath, handlers, parameters);
+    }
+
+    /**
+     * @param contextXPath
+     * @param parameters
+     */
+    private void clearParametersAtThisXPath(String contextXPath, Map parameters) {
+
+        // TODO: Slow but works, improve parameters mechanism overall
+        // to make this unecessary
+        if (contextXPath == null || parameters == null) {
+            return;
+        }
+
+        // We want to clear both /compositeFragment and /composite
+        // subtrees when we come across the root of either..
+        if (contextXPath.equals("/compositeFragment")) {
+            //clear both this and "composite"
+            contextXPath = "/composite";
+        }
+
+        Set parms = parameters.entrySet();
+        if (null != parms) {
+            Iterator iter = parms.iterator();
+            Map.Entry item = null;
+            String thisKey;
+
+            while (iter.hasNext()) {
+                item = (Entry) iter.next();
+                thisKey = (String) item.getKey();
+                if (thisKey.startsWith(contextXPath)) {
+                    //System.out.println(" removing " + thisKey + " for " +
+                    // item.getValue().toString() + " against " + contextXPath);
+                    iter.remove();
+                }
+            }
+        }
+    }
+}
\ No newline at end of file

Propchange: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/GenericDomNodeHandler.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/GenericDomNodeHandler.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Added: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/LittleClass.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/LittleClass.java?view=auto&rev=556089
==============================================================================
--- incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/LittleClass.java (added)
+++ incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/LittleClass.java Fri Jul 13 11:26:14 2007
@@ -0,0 +1,33 @@
+/**
+ *
+ *  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.
+ */
+
+/* @version $Rev$ $Date$ */
+
+package org.apache.tuscany.sca.cpp.tools.services;
+
+/**
+ * This class is just a convenient application class that is loaded in order to
+ * get the application class loader. We are interested in the application class
+ * loader as we use its getResource method to resolve XML files independantly of
+ * where they are.
+ */
+public class LittleClass {
+
+}
\ No newline at end of file

Propchange: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/LittleClass.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/LittleClass.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Added: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/ReferenceDomNodeHandler.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/ReferenceDomNodeHandler.java?view=auto&rev=556089
==============================================================================
--- incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/ReferenceDomNodeHandler.java (added)
+++ incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/ReferenceDomNodeHandler.java Fri Jul 13 11:26:14 2007
@@ -0,0 +1,75 @@
+/**
+ *
+ *  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.
+ */
+
+/* @version $Rev$ $Date$ */
+
+package org.apache.tuscany.sca.cpp.tools.services;
+
+import java.util.Map;
+
+import org.apache.tuscany.sca.cpp.tools.common.Options;
+import org.w3c.dom.Node;
+
+/**
+ * The purpose of this class is to process a <reference>element in a
+ * componentType file and then trigger a call to the method in ServicesGenerator
+ * to process the interface header file
+ */
+public class ReferenceDomNodeHandler extends GenericDomNodeHandler {
+
+    /*
+     * (non-Javadoc)
+     * 
+     * @see org.apache.tuscany.sca.cpp.services.DomNodeHandler#handleNode(org.w3c.dom.Node,
+     *      java.lang.String, java.util.Map, java.util.Map)
+     */
+    public void handleNode(Node node, String contextXPath, Map handlers,
+            Map parameters) {
+
+        // Pick up attrs and children
+        super.handleNode(node, contextXPath, handlers, parameters);
+
+        //OK we know we are handling a reference
+        //now go and create the wrapper and proxy for it if it is a C++ reference
+        if(parameters.containsKey("/componentType/reference/interface.cpp/@header")) {
+            createProxyForReference(parameters);
+        }
+
+    }
+
+    /**
+     * This method is really just an adapter that adapts the -dir Option to a
+     * value int he parameters map for "composite_root"
+     * 
+     * @param parameters
+     *            the map of name-value parameters.
+     */
+    private void createProxyForReference(Map parameters) {
+        try {
+            String mr = (String) Options.getOption("-dir");
+            parameters.put("composite_root", mr);
+            ServicesGenerator.handleInterfaceHeader(parameters, true);
+
+        } catch (Exception e) {
+            e.printStackTrace();
+        }
+
+    }
+}

Propchange: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/ReferenceDomNodeHandler.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/ReferenceDomNodeHandler.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Added: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/Scagen.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/Scagen.java?view=auto&rev=556089
==============================================================================
--- incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/Scagen.java (added)
+++ incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/Scagen.java Fri Jul 13 11:26:14 2007
@@ -0,0 +1,176 @@
+/**
+ *
+ *  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.
+ */
+
+/* @version $Rev$ $Date$ */
+
+package org.apache.tuscany.sca.cpp.tools.services;
+
+import java.io.File;
+import java.util.Arrays;
+import java.util.HashSet;
+import java.util.Set;
+
+import org.apache.tuscany.sca.cpp.tools.common.CParsingTool;
+import org.apache.tuscany.sca.cpp.tools.common.Options;
+import org.apache.tuscany.sca.cpp.tools.common.Utils;
+
+/**
+ * This is the main top level class. Its purpose is to create a
+ * Composite/FragmentFile handler visitor and pass it to a DirectoryScanner for
+ * processing.
+ */
+public class Scagen extends CParsingTool {
+
+    public static Set COMPOSITE_EXTENSIONS = new HashSet(Arrays
+            .asList(new Object[] { "composite", "fragment" }));
+
+    /**
+     * @throws Exception
+     *  
+     */
+    public Scagen(String[] args) throws Exception {
+        super(args);
+    }
+
+    /**
+     * Take a directory scanning class and create a vistor that knows how to
+     * handle any .composite or .fragment that the scanner comes across.
+     * 
+     * @param args
+     *            standard main args. THe values we expect in this class are
+     *            scagen -dir input_dir -output output_dir
+     *  
+     */
+    public static void main(String[] args) {
+        boolean failed = false;
+        try {
+            Scagen env = new Scagen(args);
+            CompositeOrFragmentFileHandler composite_handler = new CompositeOrFragmentFileHandler();
+
+            // Check and access the input SCA composite directory
+            String name = (String) Options.getOption("-dir");
+            if (null == name) {
+                Utils
+                        .screenMessage("Please provide a SCA composite directory name as a \"-dir\" option.");
+                env.printUsage();
+                System.exit(-1);
+            }
+            File source = new File(name);
+            if (!source.isFile() && !source.isDirectory()) {
+                Utils
+                        .screenMessage("The SCA composite directory provided as the \"-dir\" option cannot be accessed,");
+                Utils.screenMessage("the option given was: " + source);
+                env.printUsage();
+                System.exit(-1);
+            }
+
+            String deployDir = null;
+            try {
+                deployDir = (String) Options.getOption("-deploy");
+                if (null != deployDir || Options.deploy()) {
+                    Utils.setReportArtefacts(true);
+                }
+            } catch (Exception e) {
+                // let it default to null
+            }
+
+            Utils.postEvent(Utils.DEPLOYMENT_INPUT_DIRECTORY, source
+                    .getAbsolutePath());
+
+            // We check the -output option here as we wish to
+            // reuse the env.maybeCreateDirectory method
+            // unchanged from the original that went into axis and it will do a
+            // System.exit if there is no matching Option
+            String outputDirName = (String) Options.getOption("-output");
+            if (null == outputDirName) {
+                Utils
+                        .screenMessage("Please provide an output directory name for the generated files as a \"-output\" option.");
+                env.printUsage();
+                System.exit(-1);
+            }
+
+            File outputDir = new File(outputDirName);
+
+            // Check we can create the output directory
+            if (outputDir == null || !outputDir.exists() && !outputDir.mkdir()) {
+                Utils.screenMessage("Failed to create output directory: "
+                        + outputDirName);
+                env.printUsage();
+                System.exit(-1);
+            }
+
+            Utils.postEvent(Utils.DEPLOYMENT_OUTPUT_DIRECTORY, outputDir
+                    .getAbsolutePath());
+
+            DirectoryScanner scanner = new DirectoryScanner(composite_handler,
+                    COMPOSITE_EXTENSIONS);
+            scanner.walkTree(source, outputDir, 1);
+
+            if (0 == composite_handler.getFilesActedOn()) {
+                Utils
+                        .screenMessage("No SCA composite or fragment files were found in: "
+                                + source);
+            }
+
+            failed = composite_handler.failed;
+
+        } catch (Exception exception) {
+            Utils
+                    .screenMessage("Unexpected error occurred while runnning the Scagen tool. The Java exception is below.");
+            exception.printStackTrace();
+            failed = true;
+        }
+
+        if (failed) {
+            Utils
+                    .outputDebugString("Finished! (but encountered problems parsing composites)");
+            System.exit(-2);
+        }
+
+        Utils.outputDebugString("Finished!");
+    }
+
+    /**
+     * Provide a hint to the user on how to call this class
+     */
+    protected void printUsage() {
+        System.out
+                .println("usage: Java Scagen -dir <input_directory> -output <output_directory> [-verbose] [-deploy <deploy_dir>] [-nogenerate] [-outputCommand] [-command <copy_cmd>]");
+        System.out
+                .println("       -dir <input_directory>: the SCA composite root directory");
+        System.out
+                .println("       -output <output_directory>: a directory to put the generated output into");
+        System.out.println("       [-verbose]: report on what scagen is doing");
+        System.out
+                .println("       [-deploy <deploy_dir>]: output text to help in deploying the composite's artefacts");
+        System.out
+                .println("       [-command <copy_cmd>]: a string that is injected into the deploy text");
+        System.out
+                .println("       [-list]: change the deploy output text to a simple list of artefacts");
+        System.out
+                .println("       [-outputCommand]: change the deploy output text to command text format");
+        System.out
+                .println("                       output is of form \"copy_cmd <dir>file1 <deploy_dir>file1\"");
+        System.out
+                .println("       [-nogenerate]: do not generate proxies and wrappers");
+
+    }
+
+}
\ No newline at end of file

Propchange: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/Scagen.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/Scagen.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Added: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/ServiceDomNodeHandler.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/ServiceDomNodeHandler.java?view=auto&rev=556089
==============================================================================
--- incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/ServiceDomNodeHandler.java (added)
+++ incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/ServiceDomNodeHandler.java Fri Jul 13 11:26:14 2007
@@ -0,0 +1,71 @@
+/**
+ *
+ *  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.
+ */
+
+/* @version $Rev$ $Date$ */
+
+package org.apache.tuscany.sca.cpp.tools.services;
+
+import java.util.Map;
+
+import org.apache.tuscany.sca.cpp.tools.common.Options;
+import org.w3c.dom.Node;
+
+public class ServiceDomNodeHandler extends GenericDomNodeHandler {
+
+    /*
+     * (non-Javadoc)
+     * 
+     * @see org.apache.tuscany.sca.cpp.services.DomNodeHandler#handleNode(org.w3c.dom.Node,
+     *      java.lang.String, java.util.Map, java.util.Map)
+     */
+    public void handleNode(Node node, String contextXPath, Map handlers,
+            Map parameters) {
+
+        // Pick up attrs and the interface.cpp child elements
+        super.handleNode(node, contextXPath, handlers, parameters);
+
+        // Only generate if this is a C++ service
+        if(parameters.containsKey("/componentType/service/interface.cpp/@header")) {
+            //OK now go and create the wrapper and proxy for the service
+            createWrapperAndProxyForService(parameters);
+        }
+
+    }
+
+    /**
+     * This method will generate the wrapper and proxy C++ and header files for
+     * the service.
+     * 
+     * @param parameters
+     *            a map of name-value parameters
+     */
+    private void createWrapperAndProxyForService(Map parameters) {
+
+        try {
+            String mr = (String) Options.getOption("-dir");
+            parameters.put("composite_root", mr);
+            ServicesGenerator.handleInterfaceHeader(parameters, false);
+
+        } catch (Exception e) {
+            e.printStackTrace();
+        }
+
+    }
+}

Propchange: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/ServiceDomNodeHandler.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/ServiceDomNodeHandler.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Added: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/ServicesGenerator.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/ServicesGenerator.java?view=auto&rev=556089
==============================================================================
--- incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/ServicesGenerator.java (added)
+++ incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/ServicesGenerator.java Fri Jul 13 11:26:14 2007
@@ -0,0 +1,831 @@
+/**
+ *
+ *  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.
+ */
+
+/* @version $Rev$ $Date$ */
+
+package org.apache.tuscany.sca.cpp.tools.services;
+
+import java.io.File;
+import java.io.IOException;
+import java.io.InputStream;
+import java.util.Iterator;
+import java.util.List;
+import java.util.Map;
+
+import javax.xml.parsers.DocumentBuilder;
+import javax.xml.parsers.DocumentBuilderFactory;
+import javax.xml.parsers.ParserConfigurationException;
+import javax.xml.transform.Transformer;
+import javax.xml.transform.TransformerConfigurationException;
+import javax.xml.transform.TransformerException;
+import javax.xml.transform.TransformerFactory;
+import javax.xml.transform.dom.DOMSource;
+import javax.xml.transform.stream.StreamResult;
+import javax.xml.transform.stream.StreamSource;
+
+import org.apache.tuscany.sca.cpp.tools.common.CParsingTool;
+import org.apache.tuscany.sca.cpp.tools.common.Headers;
+import org.apache.tuscany.sca.cpp.tools.common.Options;
+import org.apache.tuscany.sca.cpp.tools.common.Parameter;
+import org.apache.tuscany.sca.cpp.tools.common.Signature;
+import org.apache.tuscany.sca.cpp.tools.common.Utils;
+import org.w3c.dom.Attr;
+import org.w3c.dom.Document;
+import org.w3c.dom.Element;
+import org.w3c.dom.Text;
+
+/**
+ * This class is the main class that handles the function that parses a C++
+ * interface header file into a DOM that holds all the semantic information
+ * about the interface - method names, parameters and return values. It then
+ * uses XSLT to generate different "views" of this data plus the parameter map
+ * from other sources that are the C++ programs for the proxy and wrapper
+ * implementations and headers.
+ */
+public class ServicesGenerator extends CParsingTool {
+
+    private static final String OPERATION_NAME_ATTR = "operationNameAttr";
+
+    private static final String HEADER_NAME_ATTR = "headerNameAttr";
+
+    private static final String SCA_OPERATION = "scaOperation";
+
+    private static final String SCA_SERVICE = "scaService";
+
+    private static final String SCA_OPERATION_RETURN_TYPE = "scaOperationReturnType";
+
+    private static final String SCA_OPERATION_PARAMETER = "scaOperationParameter";
+
+    private static final String SCA_OPERATION_PARAMETER_NAME_ATTR = "scaOperationParameterNameAttr";
+
+    private static final String SCA_OPERATION_PARAMETER_CONST_ATTR = "scaOperationParameterConstAttr";
+
+    private static final String SCA_INTERFACE_NAME_ATTR = "scaInterfaceNameAttr";
+
+    private static final String CPP_HEADER = "cppHeader";
+
+    private static boolean TESTING = true;
+
+    private static TransformerFactory txmf = null;
+
+    private static ServicesGenerator instance = null;
+
+    public ServicesGenerator(String[] args) throws Exception {
+        super(args);
+        txmf = TransformerFactory.newInstance();
+    }
+
+    /**
+     * 
+     * @param parameters
+     * @param forReference
+     *            true if we are creating a proxy for a reference (rather than
+     *            for a service)
+     * @throws Exception
+     * 
+     * The design is
+     * <ul>
+     * <li>handleInterfaceHeader
+     * <li>createDOMofMethods
+     * <li>createProxyCPPFromDom(outputDir, dom);
+     * <li>createProxyHeaderFromDom(outputDir, dom);
+     * </ul>
+     * 
+     * plus if we are not generating for a reference element
+     * <ul>
+     * <li>createWrapperCPPFromDom(outputDir, dom);
+     * <li>createWrapperHeaderFromDom(outputDir, dom);
+     * <ul>
+     * Each of the create.... methods calls createOutputFromDom with a different
+     * style sheet.
+     *  
+     */
+    public static void handleInterfaceHeader(Map parameters,
+            boolean forReference) throws Exception {
+        boolean failed = false;
+
+        String type = null;
+        if (forReference) {
+            type = "reference";
+        } else {
+            type = "service";
+        }
+        String interfaceHeaderFilename = (String) parameters
+                .get("/componentType/" + type + "/interface.cpp/@header");
+
+        String componentTypeFileHeaderName = interfaceHeaderFilename;
+
+        String sca_composite_root =  (String) Options.getOption("-dir");
+        parameters.put("composite_root", sca_composite_root);
+
+        if (sca_composite_root != null && interfaceHeaderFilename != null
+                && interfaceHeaderFilename.length() > 0) {
+            String separator;
+            // Stick in a "/" (File.separator) if required.
+            if ((interfaceHeaderFilename.substring(0, 1).equals("/") || sca_composite_root
+                    .substring(sca_composite_root.length() - 1,
+                            sca_composite_root.length()).equals("/"))
+                    || (interfaceHeaderFilename.substring(0, 1).equals("\\") || sca_composite_root
+                            .substring(sca_composite_root.length() - 1,
+                                    sca_composite_root.length()).equals("\\"))
+
+            ) {
+                separator = "";
+            } else {
+                separator = File.separator;
+            }
+            interfaceHeaderFilename = sca_composite_root + separator
+                    + interfaceHeaderFilename;
+        }
+
+        File outputDir = (File) parameters.get("targetDirectoryFile");
+
+        String[] args = new String[] { "-source", interfaceHeaderFilename,
+                "-target", outputDir.getPath() };
+        ServicesGenerator gen = new ServicesGenerator(args);
+        File file;
+        try {
+            if (null == interfaceHeaderFilename) {
+                gen.printUsage();
+                System.exit(-1);
+            }
+
+            file = new File(interfaceHeaderFilename);
+            if (!file.isFile()) {
+                if (file.isDirectory()) {
+                    Utils
+                            .rude("This tool works at the header file level and not for directories like "
+                                    + file);
+                }
+                Utils.rude("Bad file or directory " + file);
+            }
+            File source = file;
+            if (!outputDir.exists() && !outputDir.mkdir())
+                Utils.rude("Failed to create directory " + outputDir);
+
+            // The class below is the one that will go through the header
+            // file(s)
+            Headers headers = new Headers();
+
+            if (null != interfaceHeaderFilename) {
+                Utils.postEvent(Utils.DEPLOYMENT_ARTEFACT_ENCOUNTERED, file
+                        .getAbsolutePath());
+                Utils.postEvent(Utils.EVENT_TYPE_FILE_PARSED,
+                        "Scagen processing C++ interface header "
+                                + file.getAbsolutePath());
+                headers.actOnFile(file, outputDir, 1);
+                Utils.outputDebugString("Parsing files...");
+            }
+
+            String nameOfSorR = null;
+            String referenceName = null;
+            String serviceName = null;
+
+            if (forReference) {
+
+                Object rn = parameters.get("/componentType/reference/@name");
+
+                if (rn instanceof String) {
+                    referenceName = (String) rn;
+                    nameOfSorR = referenceName;
+                }
+            } else {
+
+                Object sn = parameters.get("/componentType/service/@name");
+
+                if (sn instanceof String) {
+                    serviceName = (String) sn;
+                    nameOfSorR = serviceName;
+                }
+            }
+
+            String compositeXmlFileHeader = null;
+            String compositeXmlFileHeaderNoExt = null;
+            Object compositeh = parameters
+                    .get("/composite/component/implementation.cpp/@header");
+
+            if (compositeh == null) {
+                compositeh = parameters
+                        .get("/compositeFragment/component/implementation.cpp/@header");
+            }
+
+            if (compositeh instanceof String) {
+                File f = new File((String) compositeh);
+                compositeXmlFileHeader = (String) compositeh;
+
+                String fname = f.getName();
+                compositeXmlFileHeaderNoExt = fname.substring(0, fname
+                        .lastIndexOf('.'));
+
+            }
+
+            String implClassNameAttrFromCompositeFile = (String) parameters
+            	.get("implClass");
+            String implClassNamespaceAttrFromCompositeFile = (String) parameters
+            	.get("implNamespace");
+            
+            if(implClassNamespaceAttrFromCompositeFile == null || implClassNamespaceAttrFromCompositeFile.length() == 0)
+            {
+                implClassNamespaceAttrFromCompositeFile = "";
+            }
+            else
+            {
+                implClassNamespaceAttrFromCompositeFile += "::";
+            }
+            
+            String interfaceClassNameAttrFromComponentTypeFile;
+            if (forReference) {
+                interfaceClassNameAttrFromComponentTypeFile = (String) parameters
+                        .get("/componentType/reference/interface.cpp/@class");
+            } else {
+                interfaceClassNameAttrFromComponentTypeFile = (String) parameters
+                        .get("/componentType/service/interface.cpp/@class");
+            }
+
+            List methods = headers.getAllMethods();
+            
+            // Pull out one of the methods' namespace attributes.
+            String intfNamespace = null;
+            if (methods.size() > 0) {
+                Signature method = (Signature) methods.get(0);
+                intfNamespace = method.getNamespace();
+            }
+
+            if (interfaceClassNameAttrFromComponentTypeFile != null) {
+                methods = filterToPublicMethodsOfGivenClass(methods,
+                        interfaceClassNameAttrFromComponentTypeFile, true);
+            } else {
+                //We want to filter to methods of the class whose
+                //name matches the header file name.
+                //      String intfClassName = (String) parameters.get("intfClass");
+                //
+                String headerFileBase = file.getName().replaceAll(
+                        "\\.h|\\.hpp|\\.h++", "");
+
+                methods = filterToPublicMethodsOfGivenClass(methods,
+                        headerFileBase, false);
+            }
+
+            Document dom = createDOMofMethods(methods, source, serviceName,
+                    referenceName, nameOfSorR, null,
+                    componentTypeFileHeaderName, compositeXmlFileHeader,
+                    compositeXmlFileHeaderNoExt, intfNamespace,
+                    interfaceClassNameAttrFromComponentTypeFile,
+                    implClassNameAttrFromCompositeFile, implClassNamespaceAttrFromCompositeFile);
+           
+//            // Print out the generated DOM
+//            StringWriter sw = new StringWriter();
+//            OutputFormat outputFormat = new OutputFormat("xml", "UTF-8", true);
+//            XMLSerializer serializer = new XMLSerializer(sw, outputFormat);
+//            serializer.serialize(dom);
+//            System.out.println("DOM:\n"+sw.toString()); 
+            
+            
+            createProxyCPPFromDom(outputDir, dom);
+            createProxyHeaderFromDom(outputDir, dom);
+
+            if (!forReference) {
+                createWrapperCPPFromDom(outputDir, dom);
+                createWrapperHeaderFromDom(outputDir, dom);
+            }
+
+        } catch (Exception exception) {
+            exception.printStackTrace();
+            failed = true;
+        }
+
+        if (failed) {
+            Utils.outputDebugString("Finished! (but encountered problems)");
+            System.exit(-2);
+        }
+    }
+
+    /**
+     * This methods takes a list of methods and filters them to only contain the
+     * public methods of the given class
+     * 
+     * @param methods
+     *            a list of methods
+     * @param className
+     *            we will return a list of only this classes methods from the
+     *            methods parameter
+     * @param attrSpecified
+     *            if the user does not specify one we ignore namespaces
+     * @return
+     */
+    private static List filterToPublicMethodsOfGivenClass(List methods,
+            String className, boolean useNamespace) {
+        if (methods != null && className != null && className.length() > 0) {
+            for (Iterator iter = methods.listIterator(); iter.hasNext();) {
+                Signature method = (Signature) iter.next();
+                String scope = method.getScope();
+                String sig = method.getOriginal();
+                String namespace = method.getNamespace();
+
+                String qualifiedClassName;
+                if (useNamespace && null != namespace && 0 < namespace.length()) {
+                    qualifiedClassName = namespace + "::"
+                            + method.getTrimClassName();
+                } else {
+                    qualifiedClassName = method.getTrimClassName();
+                }
+
+                // If we are not public or the classname does not match
+                // remove...
+                if (!qualifiedClassName.equals(className)
+                        || -1 == scope.indexOf("public")) {
+                    iter.remove();
+                }
+            }
+        }
+        return methods;
+    }
+
+    /**
+     * Use an XSLT transformation to create a Proxy "view" of the DOM
+     * information
+     * 
+     * @param outputDir
+     *            where to put the C++
+     * @param dom
+     *            the DOM of semantic method information
+     * @throws TransformerException
+     */
+    private static void createProxyCPPFromDom(File outputDir, Document dom)
+            throws TransformerException {
+
+        //Create the Filename from the Service Name in the DOM
+        if (dom == null) {
+            return;
+        }
+
+        String serviceOrReferenceName = "noSorRNameDefined";
+
+        String implClass = "nocompositeXmlFileHeaderDefined";
+
+        Element topNode = dom.getDocumentElement();
+        if (null != topNode) {
+            Attr attr = topNode.getAttributeNode("nameOfSorR");
+            if (attr != null) {
+                serviceOrReferenceName = attr.getNodeValue();
+            }
+
+            attr = topNode.getAttributeNode("implClass");
+            if (attr != null) {
+                implClass = attr.getNodeValue();
+            }
+        }
+
+        File proxyCPP = new File(outputDir, implClass + "_"
+                + serviceOrReferenceName + "_Proxy.cpp");
+        if (null != proxyCPP) {
+
+            Utils.postEvent(Utils.DEPLOYMENT_ARTEFACT_GENERATED, proxyCPP
+                    .getAbsolutePath());
+            Utils.postEvent(Utils.EVENT_TYPE_FILE_CREATE,
+                    "Scagen creating SCA for C++ proxy implementation "
+                            + proxyCPP.getAbsolutePath());
+        }
+
+        createOutputFromDom(dom, proxyCPP,
+                "org/apache/tuscany/sca/cpp/tools/services/xsl/SCA4CPPIntfProxyCPP.xsl");
+
+    }
+
+    /**
+     * Use an XSLT transformation to create a Wrapper "view" of the DOM
+     * information
+     * 
+     * @param outputDir
+     *            where to put the C++
+     * @param dom
+     *            the DOM of semantic method information
+     * @throws TransformerException
+     */
+    private static void createWrapperCPPFromDom(File outputDir, Document dom)
+            throws TransformerException {
+
+        //Create the Filename from the Service Name in the DOM
+        if (dom == null) {
+            return;
+        }
+
+        String serviceName = "noServiceDefined";
+
+        String implClass = "nocompositeXmlFileHeaderDefined";
+
+        Element topNode = dom.getDocumentElement();
+        if (null != topNode) {
+            Attr attr = topNode.getAttributeNode("serviceName");
+            if (attr != null) {
+                serviceName = attr.getNodeValue();
+            }
+
+            attr = topNode.getAttributeNode("implClass");
+            if (attr != null) {
+                implClass = attr.getNodeValue();
+            }
+        }
+
+        File wrapperCPP = new File(outputDir, implClass + "_" + serviceName
+                + "_Wrapper.cpp");
+        if (null != wrapperCPP) {
+            Utils.postEvent(Utils.DEPLOYMENT_ARTEFACT_GENERATED, wrapperCPP
+                    .getAbsolutePath());
+            Utils.postEvent(Utils.EVENT_TYPE_FILE_CREATE,
+                    "Scagen creating SCA for C++ wrapper implementation "
+                            + wrapperCPP.getAbsolutePath());
+        }
+        createOutputFromDom(dom, wrapperCPP,
+                "org/apache/tuscany/sca/cpp/tools/services/xsl/SCA4CPPIntfWrapperCPP.xsl");
+
+    }
+
+    /**
+     * Use an XSLT transformation to create a Proxy header "view" of the DOM
+     * information
+     * 
+     * @param outputDir
+     *            where to put the C++
+     * @param dom
+     *            the DOM of sematic method information
+     * @throws TransformerException
+     */
+    private static void createProxyHeaderFromDom(File outputDir, Document dom)
+            throws TransformerException {
+
+        //Create the Filename from the Service Name in the DOM
+        if (dom == null) {
+            return;
+        }
+
+        String serviceOrReferenceName = "noServiceDefined";
+        String intfClass = "noInterfaceClassNameOrDefaultDefined";
+        String implClass = "noImplementationClassOrDefaultDefined";
+
+        Element topNode = dom.getDocumentElement();
+        if (null != topNode) {
+            Attr attr = topNode.getAttributeNode("nameOfSorR");
+            if (attr != null) {
+                serviceOrReferenceName = attr.getNodeValue();
+            }
+            attr = topNode.getAttributeNode("intfClass");
+            if (attr != null) {
+                intfClass = attr.getNodeValue();
+            }
+            attr = topNode.getAttributeNode("implClass");
+            if (attr != null) {
+                implClass = attr.getNodeValue();
+            }
+        }
+
+        File proxyHeader = new File(outputDir, implClass + "_"
+                + serviceOrReferenceName + "_Proxy.h");
+        if (null != proxyHeader) {
+            Utils.postEvent(Utils.DEPLOYMENT_ARTEFACT_GENERATED, proxyHeader
+                    .getAbsolutePath());
+            Utils.postEvent(Utils.EVENT_TYPE_FILE_CREATE,
+                    "Scagen creating SCA for C++ proxy header "
+                            + proxyHeader.getAbsolutePath());
+        }
+
+        createOutputFromDom(dom, proxyHeader,
+                "org/apache/tuscany/sca/cpp/tools/services/xsl/SCA4CPPIntfProxyHeader.xsl");
+
+    }
+
+    /**
+     * Use an XSLT transformation to create a Wrapper header "view" of the DOM
+     * information
+     * 
+     * @param outputDir
+     *            where to put the C++
+     * @param dom
+     *            the DOM of sematic method information
+     * @throws TransformerException
+     */
+    private static void createWrapperHeaderFromDom(File outputDir, Document dom)
+            throws TransformerException {
+
+        //Create the Filename from the Service Name in the DOM
+        if (dom == null) {
+            return;
+        }
+
+        String serviceName = "noServiceDefined";
+
+        String implClass = "nocompositeXmlFileHeaderDefined";
+
+        Element topNode = dom.getDocumentElement();
+        if (null != topNode) {
+            Attr attr = topNode.getAttributeNode("serviceName");
+            if (attr != null) {
+                serviceName = attr.getNodeValue();
+            }
+
+            attr = topNode.getAttributeNode("implClass");
+            if (attr != null) {
+                implClass = attr.getNodeValue();
+            }
+        }
+
+        File wrapperHeader = new File(outputDir, implClass + "_" + serviceName
+                + "_Wrapper.h");
+
+        if (null != wrapperHeader) {
+            Utils.postEvent(Utils.DEPLOYMENT_ARTEFACT_GENERATED, wrapperHeader
+                    .getAbsolutePath());
+            Utils.postEvent(Utils.EVENT_TYPE_FILE_CREATE,
+                    "Scagen creating SCA for C++ wrapper header "
+                            + wrapperHeader.getAbsolutePath());
+        }
+        createOutputFromDom(dom, wrapperHeader,
+                "org/apache/tuscany/sca/cpp/tools/services/xsl/SCA4CPPIntfWrapperHeader.xsl");
+
+    }
+
+    /**
+     * This method will return a class loader that can see the resources that
+     * are parts of "this" package.
+     */
+    private static ClassLoader getALoader() {
+
+        LittleClass lc;
+        try {
+            lc = new LittleClass();
+            return lc.getClass().getClassLoader();
+        } catch (Exception e) {
+            e.printStackTrace();
+        }
+        return null;
+    }
+
+    /**
+     * This method will generically process the DOM using a stylesheet passed
+     * in.
+     * 
+     * @param dom
+     *            the source of data (the model)
+     * @param outputFile
+     *            where to put the result
+     * @param xslTransformationFileName
+     *            the xsl file containing the "view"
+     * @throws TransformerException
+     */
+    private static void createOutputFromDom(Document dom, File outputFile,
+            String xslTransformationFileName) throws TransformerException {
+        
+        if(Options.noGenerate()){
+            return;
+        }
+        
+        InputStream stream = getALoader().getResourceAsStream(
+                xslTransformationFileName);
+        StreamSource ss = new StreamSource(stream);
+        StreamResult out = new StreamResult(outputFile);
+        try {
+            Transformer xslt = txmf.newTransformer(ss);
+
+            // Unless a width is set, there will be only line breaks but no
+            // indentation.
+            // The IBM JDK and the Sun JDK don't agree on the property name,
+            // so we set them both.
+            //
+            try {
+                xslt.setOutputProperty(
+                        "{http://xml.apache.org/xalan}indent-amount", "2");
+            } catch (Throwable t) {
+                //OK to ignore this, depends on XSLT engine and one will fail
+            }
+            try {
+                xslt.setOutputProperty(
+                        "{http://xml.apache.org/xslt}indent-amount", "2");
+            } catch (Throwable t) {
+                //OK to ignore this, depends on XSLT engine and one will fail
+            }
+
+            DOMSource from = new DOMSource(dom);
+
+            xslt.transform(from, out);
+
+        } catch (TransformerConfigurationException e) {
+            e.printStackTrace();
+            throw (e);
+        } catch (TransformerException e) {
+            e.printStackTrace();
+            throw (e);
+        } finally {
+            try {
+                stream.close();
+            } catch (IOException e1) {
+                // unlikely but if
+                // we can't close it, we can't close it
+            }
+        }
+
+    }
+
+    //TODO clear up the parameter list below to make it smaller if
+    // possible
+    /**
+     * This method will create A DOM containing all the semantic information
+     * that it can extract from a C++ header file.
+     * 
+     * @param methods
+     *            a list of methods that are going into the DOM
+     * @param source
+     *            the header file the methods came from
+     * @param serviceName
+     *            the name of the service
+     * @referenceName the name of the reference
+     * @nameOfSorR the non null one of the two parameters above
+     * @headerClassName the name of the header class
+     * @param compositeXmlFileImplHeaderNameWithPathAndExt
+     *            the source filename
+     * @param compositeXmlFileHeaderNoExtorPath
+     *            the shortname of the source file
+     * @param implClass
+     *            the implementation class
+     * @param intfClass
+     *            the interface we are turning into a service
+     * @return
+     */
+    private static Document createDOMofMethods(List methods, File source,
+            String serviceName, String referenceName, String nameOfSorR,
+            String headerClassName,
+            String componentTypeXmlFileIntfHeaderNameWithPathAndExt,
+            String compositeXmlFileImplHeaderNameWithPathAndExt,
+            String compositeXmlFileHeaderNoExtorPath, String intfNamespace,
+            String intfClass, String implClass, String implNamespace) {
+
+        if (methods == null) {
+            return null;
+        }
+
+        // Create a DOM of the methods
+        DocumentBuilderFactory factory = DocumentBuilderFactory.newInstance();
+        Document document = null;
+        try {
+            DocumentBuilder builder = factory.newDocumentBuilder();
+            document = builder.newDocument();
+
+            Element root = (Element) document.createElement(CPP_HEADER);
+
+            root.setAttribute(HEADER_NAME_ATTR, source.getPath());
+
+            document.appendChild(root);
+
+            Element intf = (Element) document.createElement(SCA_SERVICE);
+            root.appendChild(intf);
+
+            // Go through all the signatures we have collected...
+            Signature s = null;
+            for (Iterator iter = methods.iterator(); iter.hasNext();) {
+                s = (Signature) iter.next();
+
+                // Each signature is an operation
+                Element op = document.createElement(SCA_OPERATION);
+                op.setAttribute(OPERATION_NAME_ATTR, s.getMethodName());
+                intf.appendChild(op);
+
+                Parameter[] parms = s.getParameters();
+                if (parms != null) {
+
+                    for (int i = 0; i < parms.length; i++) {
+                        Element parm = (Element) document
+                                .createElement(SCA_OPERATION_PARAMETER);
+                        String type_string = parms[i].getTypeWithoutConst()
+                                .toString();
+
+                        type_string = type_string.replaceAll(":: ", "::");
+
+                        Text text = document.createTextNode(type_string);
+                        parm.appendChild(text);
+                        parm.setAttribute(SCA_OPERATION_PARAMETER_NAME_ATTR,
+                                parms[i].getName());
+
+                        if (parms[i].getTypeWithoutConst().intern() != parms[i]
+                                .getType().intern()) {
+                            parm.setAttribute(
+                                    SCA_OPERATION_PARAMETER_CONST_ATTR, "true");
+                        }
+
+                        op.appendChild(parm);
+                        // TO DO only really stores the value
+                        // unsafely/temporarily
+                        // which is fine while we handle everything at the
+                        // end of parsing the "leaf" that represents that actual
+                        // interface/service but the below will cause the second
+                        // service
+                        // processed to overwite the first one in the DOM. I we
+                        // wish
+                        // to do some overall processing at the end we will have
+                        // to
+                        // use a better more XPath like key that varies by
+                        // instance
+                        // of the service.
+                        intf.setAttribute(SCA_INTERFACE_NAME_ATTR, s
+                                .getTrimClassName());
+                    }
+                }
+
+                Element rc = document.createElement(SCA_OPERATION_RETURN_TYPE);
+                rc.appendChild(document.createTextNode(s.getReturnType()
+                        .toString().replaceAll(":: ", "::")));
+                op.appendChild(rc);
+
+                root.appendChild(intf);
+            }
+
+            // Set the name of the Service
+            // here, if we are not passed one we use
+            // the classname from the last header function signature...
+            if (serviceName == null && s != null) {
+                serviceName = s.getTrimClassName();
+            }
+
+            // this is used for the proxy file name but we need to
+            // use the reference name if this is pulled in due to it
+            // being a reference!!!
+            if (serviceName != null)
+                root.setAttribute("serviceName", serviceName);
+            if (referenceName != null)
+                root.setAttribute("referenceName", referenceName);
+            if (nameOfSorR != null)
+                root.setAttribute("nameOfSorR", nameOfSorR);
+
+            if (implClass != null) {
+                root.setAttribute("implClass", implClass);
+            } else {
+                root.setAttribute("implClass", compositeXmlFileHeaderNoExtorPath);
+            }
+
+            if (implClass != null) {
+                root.setAttribute("implNamespace", implNamespace);
+            }
+
+            // default class name to the name of the header...
+            if (headerClassName == null && source != null) {
+                headerClassName = source.getName().replaceAll(
+                        "\\.h|\\.hpp|\\.h++", "");
+            }
+            root.setAttribute("headerClassName", headerClassName);
+
+            if (null == intfClass) {
+                intfClass = headerClassName;
+            }
+
+            if (null != intfNamespace) {
+                root.setAttribute("namespace", intfNamespace);
+                if (null != intfClass && !intfClass.startsWith(intfNamespace)) {
+                    intfClass = intfNamespace + "::" + intfClass;
+                }
+            }
+
+            root.setAttribute("intfClass", intfClass);
+
+            if (componentTypeXmlFileIntfHeaderNameWithPathAndExt == null) {
+                componentTypeXmlFileIntfHeaderNameWithPathAndExt = "componentTypeHeader";
+            }
+            root.setAttribute("componentTypeHeader",
+                    componentTypeXmlFileIntfHeaderNameWithPathAndExt);
+
+            if (compositeXmlFileImplHeaderNameWithPathAndExt == null) {
+                compositeXmlFileImplHeaderNameWithPathAndExt = "compositeXmlFileImplHeader";
+            }
+            root.setAttribute("compositeXmlFileHeader",
+                    compositeXmlFileImplHeaderNameWithPathAndExt);
+
+            if (compositeXmlFileHeaderNoExtorPath == null) {
+                compositeXmlFileHeaderNoExtorPath = "compositeXmlFileHeaderNoExt";
+            }
+            root.setAttribute("compositeXmlFileHeaderNoExt",
+                    compositeXmlFileHeaderNoExtorPath);
+
+        } catch (ParserConfigurationException pce) {
+            // Parser with specified options can't be built
+            pce.printStackTrace();
+        }
+
+        return document;
+
+    }
+
+}
\ No newline at end of file

Propchange: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/ServicesGenerator.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/ServicesGenerator.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Added: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/XMLFileActor.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/XMLFileActor.java?view=auto&rev=556089
==============================================================================
--- incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/XMLFileActor.java (added)
+++ incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/XMLFileActor.java Fri Jul 13 11:26:14 2007
@@ -0,0 +1,208 @@
+/**
+ *
+ *  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.
+ */
+
+/* @version $Rev$ $Date$ */
+
+package org.apache.tuscany.sca.cpp.tools.services;
+
+import java.io.File;
+import java.io.IOException;
+import java.util.HashMap;
+import java.util.Map;
+
+import javax.xml.parsers.DocumentBuilder;
+import javax.xml.parsers.DocumentBuilderFactory;
+import javax.xml.parsers.ParserConfigurationException;
+import javax.xml.transform.TransformerFactory;
+import javax.xml.transform.dom.DOMResult;
+import javax.xml.transform.dom.DOMSource;
+
+import org.apache.tuscany.sca.cpp.tools.common.FileActor;
+import org.apache.tuscany.sca.cpp.tools.common.Utils;
+import org.w3c.dom.Document;
+import org.xml.sax.SAXException;
+
+/**
+ * The purpose of this abstract class is to provide a home for the standard
+ * processing that is involved in turning a XML file into an internal DOM.
+ */
+public abstract class XMLFileActor implements FileActor {
+
+    protected static Map handlers = new HashMap();
+
+    protected static Map parameters = new HashMap();
+
+    public boolean failed;
+    
+    private int filesActedOn=0;
+
+    protected static TransformerFactory transformerFactory = TransformerFactory
+            .newInstance();
+
+    /**
+     * This method is the main FileActor method
+     * 
+     * @see FileActor#actOnFile(File, File, int) Here we create an initial DOM
+     *      and kick off the processing (using the handler map that has been set
+     *      up by the concrete subclass).
+     * 
+     * @param compositeXML
+     *            the composite or fragment file
+     * @param target
+     *            the target directory
+     * @param depth
+     *            not uesed here but in the
+     * @see FileActor#actOnFile(File, File, int) interface to allow for
+     *      recursive diving into a directory structure.
+     */
+    public void actOnFile(File compositeXML, File target, int depth)
+            throws Exception {
+
+        if (null == compositeXML || null == target) {
+            return;
+        }
+
+        filesActedOn++;
+        
+        parameters.put("sourceFile", compositeXML);
+        parameters.put("targetFile", target);
+
+        if (transformerFactory.getFeature(DOMSource.FEATURE)
+                && transformerFactory.getFeature(DOMResult.FEATURE)) {
+            Document dom = createDomFromXMLFile(compositeXML);
+            if (dom != null) {
+                parameters.put("targetDirectoryFile", target);
+                DomHandler.handleDom(dom, handlers, parameters);
+            }
+        }
+    }
+
+    /**
+     * This method builds an in memory DOM from an XML file
+     * 
+     * @param xmlSourceFile
+     *            the XML file we are handling
+     * @return the resulting document
+     */
+    protected Document createDomFromXMLFile(File xmlSourceFile) {
+        Document dom = null;
+        DocumentBuilderFactory f = DocumentBuilderFactory.newInstance();
+        //We do not validate via f.setValidating(true);
+        f.setNamespaceAware(true);
+
+        try {
+            DocumentBuilder parser = f.newDocumentBuilder();
+            dom = parser.parse(xmlSourceFile);
+        } catch (SAXException sxe) {
+            String path;
+            try {
+                path = xmlSourceFile.getCanonicalPath();
+            } catch (IOException e) {
+                path = xmlSourceFile.getPath();
+            }
+            Utils.screenMessage("There has been a SAXException of type "
+                    + sxe.getLocalizedMessage());
+            if (null != xmlSourceFile) {
+                Utils.screenMessage(" when processing file " + path);
+            } else {
+                Utils.screenMessage(" as the input file is null.");
+            }
+
+// Leave for possible future debug option
+//            Utils.screenMessage(" The returned Java exception is below.");
+//            if (sxe.getException() != null)
+//                sxe.getException().printStackTrace();
+//            else
+//                sxe.printStackTrace();
+        } catch (ParserConfigurationException pce) {
+            String path;
+            try {
+                path = xmlSourceFile.getCanonicalPath();
+            } catch (IOException e) {
+                path = xmlSourceFile.getPath();
+            }
+            Utils
+                    .screenMessage("There has been a ParserConfigurationException of type "
+                            + pce.getLocalizedMessage());
+            if (null != xmlSourceFile) {
+                Utils.screenMessage(" when processing file " + path);
+            } else {
+                Utils.screenMessage(" as the input file is null.");
+            }
+            
+//          Leave for possible future debug option
+//          Utils.screenMessage(" The returned Java exception is below.");
+//          pce.printStackTrace();
+            
+        } catch (IOException ioe) {
+            String path;
+            try {
+                path = xmlSourceFile.getCanonicalPath();
+            } catch (IOException e) {
+                path = xmlSourceFile.getPath();
+            }
+            
+            Utils.screenMessage("Unable to open file  " + path);
+            Utils.screenMessage(this.getContextMessage());
+            
+            
+            
+        }
+
+        return dom;
+    }
+
+    /**
+     * @return an error message - usually over-ridden.
+     */
+    private String getContextMessage() {
+        return "Check the file exists and can be read.";
+    }
+
+    /**
+     * Set a parameter
+     * 
+     * @param name
+     * @param value
+     */
+    public void setParameter(String name, Object value) {
+        parameters.put(name, value);
+    }
+
+    /**
+     * Get a parameter
+     * 
+     * @param name
+     * @param value
+     * @return the value of the parameter
+     */
+    public Object getParameter(String name, Object value) {
+        return parameters.get(name);
+    }
+
+
+
+    /**
+     * @return Returns the filesActedOn.
+     */
+    public int getFilesActedOn() {
+        return filesActedOn;
+    }
+}
\ No newline at end of file

Propchange: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/XMLFileActor.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/XMLFileActor.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Added: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/package.html
URL: http://svn.apache.org/viewvc/incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/package.html?view=auto&rev=556089
==============================================================================
--- incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/package.html (added)
+++ incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/package.html Fri Jul 13 11:26:14 2007
@@ -0,0 +1,159 @@
+<!--
+   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.
+-->
+
+<html>
+
+<head>
+<title>Design documentation for org\apache\tuscany\sca\cpp\tools\services</title>
+</head>
+
+<body lang=EN-GB>
+
+<div class=Section1>
+
+<h1>Overview</h1>
+
+
+
+<p>This package contains classes that generate C++ wrappers and
+proxies for C++ implementations of SCA services. </p>
+
+<h2>What the package does</h2>
+
+<p>The Scagen class main method will take in an input and
+output directory name. The input directory is taken to be the SCA composite root
+directory.  The tool will generate the wrapper and proxy headers and methods
+bodies in the output directory. </p>
+
+<p>These proxies and wrappers enable the SCA for C++ runtime to
+act as a conduit for SCA C++ calls in a type free manner. Client code can call
+the type specific functions that are in the generated proxy classes. The call
+is marshalled into a generic format and a SCA for C++ runtime function with a
+standard signature is invoked. The details of the call are passed as data. </p>
+
+<p>On the other end of the runtime, a generated function with a
+standard signature is called, this function will inspect the data that
+represents the call’s method name and call the appropriate type specific
+function in the C++ implementation. </p>
+
+<h2>The Input Data Used</h2>
+
+<p>The input directory passed to the Scagen method is taken to
+be the SCA composite root directory. All the sca.composite and .fragment files in
+that directory are inspected to resolve all the &lt;component/&gt; elements
+within them. </p>
+
+<p>Each &lt;component/&gt; element found is inspected to see if
+it has a &lt;implementation.cpp/&gt; element within it. </p>
+
+<p>Each &lt;implementation.cpp/&gt; element should have a
+header attribute that represents a C++ header file that contains function
+prototypes for the C++ implementation of the service. An optional class
+attribute can be used to select one class if more than one that is present in
+the header file. The default class is the one with the same name as the header
+file. The tool will verify that the implementation header contains an
+appropriate class prototype. </p>
+
+
+
+<p>The directory that contains the implementation header should
+also contain a matching .componentType file for the equivalent SCA component. So
+for example, a MyServiceImpl.h file would have a corresponding MyServiceImpl.componentType
+file in the same directory. </p>
+
+
+
+<p>Each componentType file is inspected for &lt;service/&gt;
+and &lt;reference/&gt; elements. For each &lt;service/&gt; element that is
+found that contains a &lt;interface.cpp/&gt; element within it,</p>
+
+<p>the header attribute of the &lt;interface.cpp/&gt; is taken
+as the filename of the C++ interface header for the SCA service.  This C++
+header file is opened and used as a means for specifying the SCA service
+resulting in an appropriate wrapper and proxy being generated for this service
+interface. Both method bodies and headers are generated in the given output
+directory. The processing of a &lt;reference/&gt; element is the same except
+that only a proxy header and implementation are generated. </p>
+
+
+
+
+
+<h2>Outline Design: How it Works</h2>
+
+
+
+<p>The basic approach is to scan in the XML files by first
+creating a DOM document tree of them and then recursively rifling through the DOM 
+with some generic code in the XMLFileActorClass by default this processing will
+build up a map which maps the XPath location of attributes to their values.
+Additionally subclasses can add to a “handlers map” which maps from the name of
+a particular element to an object that implements the DomNodeHandler interface.
+If the XMLFileActor code comes across any element that has an equivalent handler
+in the handler map the objects handleNode method will be called. </p>
+
+<p>Typically the DomNodeHandler’s handle node interface will
+use XPath to pull out the parameters that it is interested in from the
+parameters map that is being built up by the generic code. </p>
+
+<p>This design was chosen as the Java level specified for the
+original implementation did not have direct XPath query of XML data but it was
+known that this would be available in Java 1.5 onwards. The design allows the
+DOM and parameters map handling to be replaced in the future with JRE 1.5 code
+with less impact on the rest of the code.</p>
+
+
+
+<p>The processing leads to the parsing of the C++ interface
+files using the org\apache\tuscany\sca\cpp\tools\common package. This results
+in a Headers object</p>
+
+<p>that contains a List of Signature objects, each one
+representing a function prototype found in the header. </p>
+
+
+
+<p>We are aiming to get all the semantic data we want to use
+into a DOM document (this represents the model of our input data) and then use
+XSLT to create the 4 different views of this data:</p>
+
+<p>Proxy C++ header</p>
+
+<p>Proxy C++  body</p>
+
+<p>Wrapper C++ header</p>
+
+<p>Wrapper C++ body</p>
+
+
+
+<p>So we prepopulate the DOM with parameter data that comes
+from the XML files and then iterate through the Signatures that are returned
+from the C++ header parser transferring the useful data into the DOM. </p>
+
+
+
+<p>We than use 4 XSLT stylesheets to generate the C++ output
+files as required. </p>
+
+</div>
+
+</body>
+
+</html>

Propchange: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/package.html
------------------------------------------------------------------------------
    svn:eol-style = native

Added: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/xsl/SCA4CPPIntfProxyCPP.xsl
URL: http://svn.apache.org/viewvc/incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/xsl/SCA4CPPIntfProxyCPP.xsl?view=auto&rev=556089
==============================================================================
--- incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/xsl/SCA4CPPIntfProxyCPP.xsl (added)
+++ incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/xsl/SCA4CPPIntfProxyCPP.xsl Fri Jul 13 11:26:14 2007
@@ -0,0 +1,278 @@
+<!--
+   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.
+-->
+<!--
+
+ TODO There is duplication in the "..no_parms" templates with
+      the equivalent templates they are based on - that it would be 
+      fairly easy to factor out. 
+-->
+<xsl:stylesheet xmlns:xsl="http://www.w3.org/1999/XSL/Transform" version="1.0">
+<!-- Part of the org.apache.tuscany.sca.cpp.tools.services packages
+   
+     This stylesheet creates the CPP implementation of the 
+     proxy body for a given SCA service
+  --> 
+<xsl:output method="text"/>
+ 
+<!-- We do not generate output sourced from cppScopes -->
+<xsl:template match="cppScope"></xsl:template>
+
+<!-- We do not generate output sourced from private scaOperations -->
+<xsl:template match="scaOperation[@cppScope='private']">
+</xsl:template>
+
+<!-- We do not generate output sourced from the operation return types -->
+<xsl:template match="scaOperationReturnType">
+</xsl:template>
+
+
+<!--
+    CPP Header/Root
+-->
+<xsl:template match="cppHeader">/*
+ * 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.
+ */
+
+<xsl:apply-templates select="scaService" mode="include_header"/>
+
+#include "osoa/sca/sca.h"
+<xsl:apply-templates/> <!-- should go on to generic scaService below -->
+</xsl:template>
+  
+<!-- -->
+<!-- Service -->
+<!-- -->
+<xsl:template match="scaService">
+<xsl:variable name="clazz">
+   <xsl:value-of select="../@implClass"/>
+   <xsl:text>_</xsl:text>
+   <xsl:value-of select="../@nameOfSorR"/>
+   <xsl:text>_Proxy</xsl:text>
+</xsl:variable>
+<xsl:text>
+extern "C"
+{
+
+    #if defined(WIN32) || defined(_WINDOWS)
+    __declspec(dllexport) 
+    #endif
+    </xsl:text><xsl:value-of select="$clazz"/>
+<xsl:text>* </xsl:text>
+<xsl:value-of select="$clazz"/>
+<xsl:text>_Factory(tuscany::sca::ServiceWrapper* target)
+    {
+        return new </xsl:text><xsl:value-of select="$clazz"/><xsl:text>(target);
+    }
+
+    #if defined(WIN32) || defined(_WINDOWS)
+    __declspec(dllexport) 
+    #endif
+    void </xsl:text>
+<xsl:value-of select="$clazz"/>
+<xsl:text>_Destructor(void* proxy)
+    {
+        delete (</xsl:text><xsl:value-of select="$clazz"/><xsl:text>*)proxy;
+    }
+}
+
+</xsl:text>
+<xsl:value-of select="$clazz"/><xsl:text>::</xsl:text><xsl:value-of select="$clazz"/>(tuscany::sca::ServiceWrapper* targ) : target(targ)
+{
+}
+
+<xsl:value-of select="$clazz"/><xsl:text>::~</xsl:text><xsl:value-of select="$clazz"/>()
+{
+    if (target)
+        delete target;
+}<!--
+OK we have done the stuff that is not specific to any function in the service
+now we can do another apply-templates to pick up on the 0, 1 or more scaOperation
+DOM nodes that each relate to a function in the service
+ -->
+<xsl:apply-templates/>
+<!-- Always make sure we have a (visible) final newline -->
+<xsl:text>
+
+</xsl:text>
+</xsl:template>  
+
+<!--  This template is just a small function that will generate the 
+      #include that pulls in the correct C++ header
+ -->
+<xsl:template match="scaService" mode="include_header">
+<xsl:variable name="clazz">
+   <xsl:value-of select="../@implClass"/>
+   <xsl:text>_</xsl:text>
+   <xsl:value-of select="../@nameOfSorR"/>
+   <xsl:text>_Proxy</xsl:text>
+</xsl:variable>
+<xsl:text>#include "</xsl:text>
+<xsl:value-of select="$clazz"/>
+<xsl:text>.h"</xsl:text>
+</xsl:template>
+
+
+
+<!-- -->
+<!-- Operation -->
+<!-- -->
+<xsl:template match="scaOperation">
+<xsl:variable name="clazz">
+   <xsl:value-of select="../../@implClass"/>
+   <xsl:text>_</xsl:text>
+   <xsl:value-of select="../../@nameOfSorR"/>
+   <xsl:text>_Proxy</xsl:text>
+</xsl:variable>
+
+<!-- ignore the constructor and destructor -->
+<xsl:if test="@operationNameAttr != $clazz
+             and @operationNameAttr != concat('~', $clazz)" >
+<xsl:text>
+</xsl:text>
+<xsl:value-of select="scaOperationReturnType"/>
+<xsl:text> </xsl:text>
+<xsl:value-of select="$clazz"/><xsl:text>::</xsl:text>
+<xsl:value-of select="@operationNameAttr"/><xsl:text>(</xsl:text>
+<xsl:for-each select="scaOperationParameter">
+<xsl:if test=".!='void'"> 
+    <xsl:variable name="scaOperationParameterNameAttr">
+                <xsl:value-of select="concat('arg', position()-1 )"/>
+    </xsl:variable>
+    <xsl:variable name="isConst">
+       <xsl:value-of select="@scaOperationParameterConstAttr"/>
+    </xsl:variable>
+    <xsl:if test="contains($isConst,'true')">const</xsl:if><xsl:text> </xsl:text>
+    <xsl:value-of select="."/> <!-- get the actual type -->
+    <xsl:text> </xsl:text>
+    <xsl:value-of select="$scaOperationParameterNameAttr"/>
+    <xsl:choose>
+       <xsl:when test="position()=last()"> 
+       </xsl:when>
+       <xsl:otherwise>
+          <xsl:text>, </xsl:text>
+       </xsl:otherwise>
+    </xsl:choose>
+</xsl:if> <!-- test=".!='void'" -->
+
+</xsl:for-each>
+<xsl:text>)
+{</xsl:text>
+<xsl:call-template name="proxy_method_body"/>
+<xsl:text>
+}
+</xsl:text>      
+</xsl:if>
+</xsl:template>
+
+
+<xsl:template name="proxy_method_body">
+   <xsl:variable name="noOfParms">
+      <xsl:choose>
+        <xsl:when test=".='void'">
+<xsl:text>0</xsl:text>
+        </xsl:when>
+        <xsl:otherwise>
+            <xsl:value-of select="last()"/>
+        </xsl:otherwise>
+      </xsl:choose>
+    </xsl:variable>
+<xsl:text>
+    tuscany::sca::Operation operation("</xsl:text>
+    <xsl:value-of select="@operationNameAttr"/>
+    <xsl:text>");</xsl:text>
+    <xsl:if test="$noOfParms!=0">
+    <xsl:for-each select="scaOperationParameter">
+        <xsl:call-template name="proxy_method_body_set_parameter"/>
+    </xsl:for-each>
+    </xsl:if>
+    <xsl:call-template name="proxy_method_body_prepare_return_var"/>
+    <xsl:text>
+    target-&gt;invoke(operation);</xsl:text>
+    <xsl:call-template name="proxy_method_body_return"/>
+</xsl:template>
+
+
+<xsl:template name="proxy_method_body_return">
+    <xsl:variable name="type">
+        <xsl:value-of select="scaOperationReturnType/text()"/>
+    </xsl:variable>
+    <xsl:choose>
+        <xsl:when test="$type='void'"><!-- nothing -->
+            <xsl:text>
+    return;</xsl:text>
+        </xsl:when>
+        <xsl:when test="contains($type, '&amp;')"><!-- reference -->
+            <xsl:variable name="type_no_amp">
+                <xsl:value-of select="substring-before($type, '&amp;')"/>
+            </xsl:variable>
+            <xsl:text>
+    return *(</xsl:text><xsl:value-of select="$type_no_amp"/><xsl:text>*)operation.getReturnValue();</xsl:text>
+        </xsl:when>
+        <xsl:otherwise><!-- simple type -->
+        <xsl:text>
+    return *(</xsl:text><xsl:value-of select="$type"/><xsl:text>*)operation.getReturnValue();</xsl:text>
+        </xsl:otherwise>
+    </xsl:choose>
+</xsl:template>
+
+<xsl:template name="proxy_method_body_prepare_return_var">
+    <xsl:variable name="type">
+        <xsl:value-of select="scaOperationReturnType/text()"/>
+    </xsl:variable>
+    <xsl:choose>
+        <xsl:when test="$type='void'"><!-- nothing -->
+        <!--  nothing -->
+        </xsl:when>
+        <xsl:when test="contains($type, '&amp;')"><!-- reference -->
+        </xsl:when>
+        <xsl:otherwise>
+<xsl:text>
+    </xsl:text>    <xsl:value-of select="$type"/><xsl:text> ret;
+    operation.setReturnValue(&amp;ret);</xsl:text>
+        </xsl:otherwise>
+    </xsl:choose>
+
+</xsl:template>
+
+ 
+<xsl:template name="proxy_method_body_set_parameter">
+    <xsl:variable name="scaOperationParameterNameAttrInner">
+                <xsl:value-of select="concat('arg', position()-1 )"/>
+    </xsl:variable>
+    <xsl:variable name="type">
+        <xsl:value-of select="."/>
+    </xsl:variable>
+    operation.addParameter("<xsl:value-of select="@scaOperationParameterNameAttr"/>", &amp;<xsl:value-of select="$scaOperationParameterNameAttrInner"/><xsl:text>);</xsl:text>
+</xsl:template>
+</xsl:stylesheet>

Propchange: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/xsl/SCA4CPPIntfProxyCPP.xsl
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/tuscany/cpp/sca/runtime/extensions/cpp/tools/scagen/src/org/apache/tuscany/sca/cpp/tools/services/xsl/SCA4CPPIntfProxyCPP.xsl
------------------------------------------------------------------------------
    svn:keywords = Rev Date



---------------------------------------------------------------------
To unsubscribe, e-mail: tuscany-commits-unsubscribe@ws.apache.org
For additional commands, e-mail: tuscany-commits-help@ws.apache.org