You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@tuscany.apache.org by rf...@apache.org on 2011/10/03 07:18:05 UTC

svn commit: r1178299 - in /tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc: protocol/ provider/

Author: rfeng
Date: Mon Oct  3 05:18:04 2011
New Revision: 1178299

URL: http://svn.apache.org/viewvc?rev=1178299&view=rev
Log:
Add jsonrpc 1.0 models and the servlet to handle jsonrpc requests

Added:
    tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc10Request.java   (with props)
    tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc10Response.java   (with props)
    tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpcServlet.java   (with props)
Modified:
    tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc20Error.java
    tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc20Request.java
    tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc20Result.java
    tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/provider/JavaToSmd.java

Added: tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc10Request.java
URL: http://svn.apache.org/viewvc/tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc10Request.java?rev=1178299&view=auto
==============================================================================
--- tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc10Request.java (added)
+++ tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc10Request.java Mon Oct  3 05:18:04 2011
@@ -0,0 +1,85 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.    
+ */
+
+package org.apache.tuscany.sca.binding.jsonrpc.protocol;
+
+import org.json.JSONArray;
+import org.json.JSONException;
+import org.json.JSONObject;
+
+/**
+ * http://json-rpc.org/wiki/specification
+ * A remote method is invoked by sending a request to a remote service. The request is a single object serialized using JSON.
+ * <br>It has three properties:
+ * <ul>
+ * <li>method - A String containing the name of the method to be invoked.
+ * <li>params - An Array of objects to pass as arguments to the method.
+ * <li>id - The request id. This can be of any type. It is used to match the response with the request that it is replying to.
+ * </ul> 
+ */
+public class JsonRpc10Request {
+    private final String method;
+    private final Object id;
+    private final Object[] params;
+
+    public JsonRpc10Request(Object id, String method, Object[] params) {
+        super();
+        this.id = id;
+        this.method = method;
+        this.params = params;
+    }
+
+    public JsonRpc10Request(JSONObject req) throws JSONException {
+        super();
+
+        method = req.getString("method");
+        id = req.opt("id");
+        Object args = req.opt("params");
+        if (args instanceof JSONArray) {
+            // Positional parameters
+            JSONArray array = (JSONArray)args;
+            params = new Object[array.length()];
+            for (int i = 0; i < params.length; i++) {
+                params[i] = array.get(i);
+            }
+        } else if (args == null) {
+            params = new Object[0];
+        } else {
+            throw new IllegalArgumentException("Invalid request: params is not a JSON array - " + args);
+        }
+
+    }
+
+    public boolean isNotification() {
+        return id == null;
+    }
+
+    public String getMethod() {
+        return method;
+    }
+
+    public Object getId() {
+        return id;
+    }
+
+    public Object[] getParams() {
+        return params;
+    }
+
+}

Propchange: tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc10Request.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc10Request.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Added: tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc10Response.java
URL: http://svn.apache.org/viewvc/tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc10Response.java?rev=1178299&view=auto
==============================================================================
--- tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc10Response.java (added)
+++ tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc10Response.java Mon Oct  3 05:18:04 2011
@@ -0,0 +1,79 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.    
+ */
+
+package org.apache.tuscany.sca.binding.jsonrpc.protocol;
+
+import java.io.IOException;
+import java.io.Writer;
+
+import org.json.JSONException;
+import org.json.JSONObject;
+
+/**
+ * When the method invocation completes, the service must reply with a response. The response is a single object serialized using JSON.
+ * <br>
+ * It has three properties:
+ * 
+ * <ul>
+ * <li>result - The Object that was returned by the invoked method. This must be null in case there was an error invoking the method.
+ * <li>error - An Error object if there was an error invoking the method. It must be null if there was no error.
+ * <li>id - This must be the same id as the request it is responding to.
+ * </ul> 
+ */
+public class JsonRpc10Response {
+    private Object id;
+    private Object result;
+    private Object error;
+
+    public JsonRpc10Response(Object id, Object result, Object error) {
+        super();
+        this.id = id;
+        this.result = result;
+        this.error = error;
+        if (result != null && error != null) {
+            throw new IllegalArgumentException("Either result or error has to be null");
+        }
+    }
+
+    public JSONObject toJSONObject() throws JSONException {
+        JSONObject response = new JSONObject();
+        response.put("id", id);
+        if (result != null) {
+            response.put("result", result);
+        } else {
+            response.put("result", JSONObject.NULL);
+        }
+
+        if (error != null) {
+            response.put("error", error);
+        } else {
+            response.put("error", JSONObject.NULL);
+        }
+        return response;
+    }
+
+    public void write(Writer writer) throws IOException {
+        try {
+            toJSONObject().write(writer);
+        } catch (JSONException e) {
+            throw new IOException(e);
+        }
+    }
+
+}

Propchange: tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc10Response.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc10Response.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc20Error.java
URL: http://svn.apache.org/viewvc/tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc20Error.java?rev=1178299&r1=1178298&r2=1178299&view=diff
==============================================================================
--- tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc20Error.java (original)
+++ tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc20Error.java Mon Oct  3 05:18:04 2011
@@ -62,7 +62,7 @@ public class JsonRpc20Error extends Json
         this.data = stackTrace(t);
     }
 
-    private static String stackTrace(Throwable t) {
+    public static String stackTrace(Throwable t) {
         StringWriter sw = new StringWriter();
         t.printStackTrace(new PrintWriter(sw));
         return sw.toString();

Modified: tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc20Request.java
URL: http://svn.apache.org/viewvc/tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc20Request.java?rev=1178299&r1=1178298&r2=1178299&view=diff
==============================================================================
--- tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc20Request.java (original)
+++ tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc20Request.java Mon Oct  3 05:18:04 2011
@@ -87,4 +87,20 @@ public class JsonRpc20Request {
     public boolean isNotification() {
         return id == null;
     }
+
+    public String getMethod() {
+        return method;
+    }
+
+    public Object getId() {
+        return id;
+    }
+
+    public Object[] getParams() {
+        return params;
+    }
+
+    public Map<String, Object> getMappedParams() {
+        return mappedParams;
+    }
 }

Modified: tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc20Result.java
URL: http://svn.apache.org/viewvc/tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc20Result.java?rev=1178299&r1=1178298&r2=1178299&view=diff
==============================================================================
--- tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc20Result.java (original)
+++ tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpc20Result.java Mon Oct  3 05:18:04 2011
@@ -19,6 +19,9 @@
 
 package org.apache.tuscany.sca.binding.jsonrpc.protocol;
 
+import java.io.IOException;
+import java.io.Writer;
+
 import org.json.JSONException;
 import org.json.JSONObject;
 
@@ -31,4 +34,12 @@ public abstract class JsonRpc20Result {
     }
 
     public abstract JSONObject toJSONObject() throws JSONException;
+
+    public void write(Writer writer) throws IOException {
+        try {
+            toJSONObject().write(writer);
+        } catch (JSONException e) {
+            throw new IOException(e);
+        }
+    }
 }

Added: tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpcServlet.java
URL: http://svn.apache.org/viewvc/tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpcServlet.java?rev=1178299&view=auto
==============================================================================
--- tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpcServlet.java (added)
+++ tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpcServlet.java Mon Oct  3 05:18:04 2011
@@ -0,0 +1,313 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.    
+ */
+
+package org.apache.tuscany.sca.binding.jsonrpc.protocol;
+
+import java.io.BufferedReader;
+import java.io.IOException;
+import java.io.InputStreamReader;
+import java.io.OutputStream;
+import java.io.StringWriter;
+import java.io.UnsupportedEncodingException;
+import java.util.List;
+
+import javax.servlet.ServletException;
+import javax.servlet.http.HttpServlet;
+import javax.servlet.http.HttpServletRequest;
+import javax.servlet.http.HttpServletResponse;
+
+import org.apache.tuscany.sca.assembly.Binding;
+import org.apache.tuscany.sca.binding.jsonrpc.provider.JavaToSmd;
+import org.apache.tuscany.sca.interfacedef.Operation;
+import org.apache.tuscany.sca.invocation.Message;
+import org.apache.tuscany.sca.invocation.MessageFactory;
+import org.apache.tuscany.sca.runtime.RuntimeEndpoint;
+import org.json.JSONArray;
+import org.json.JSONObject;
+import org.oasisopen.sca.ServiceRuntimeException;
+
+public class JsonRpcServlet extends HttpServlet {
+    private static final long serialVersionUID = 1L;
+
+    transient MessageFactory messageFactory;
+
+    transient Binding binding;
+    transient String serviceName;
+    transient Object serviceInstance;
+    transient RuntimeEndpoint endpoint;
+    transient Class<?> serviceInterface;
+
+    public JsonRpcServlet(MessageFactory messageFactory,
+                          RuntimeEndpoint endpoint,
+                          Class<?> serviceInterface,
+                          Object serviceInstance) {
+        this.endpoint = endpoint;
+        this.messageFactory = messageFactory;
+        this.binding = endpoint.getBinding();
+        this.serviceName = binding.getName();
+        this.serviceInterface = serviceInterface;
+        this.serviceInstance = serviceInstance;
+    }
+
+    @Override
+    protected void service(HttpServletRequest request, HttpServletResponse response) throws ServletException,
+        IOException {
+
+        if ("smd".equals(request.getQueryString())) {
+            handleSMDRequest(request, response);
+            return;
+        }
+        try {
+            handleJsonRpcInvocation(request, response);
+
+        } catch (RuntimeException re) {
+            if (re.getCause() instanceof javax.security.auth.login.LoginException) {
+                response.setHeader("WWW-Authenticate", "BASIC realm=\"" + "ldap-realm" + "\"");
+                response.sendError(HttpServletResponse.SC_UNAUTHORIZED);
+            } else {
+                throw re;
+            }
+        }
+
+    }
+
+    private void handleJsonRpcInvocation(HttpServletRequest request, HttpServletResponse response)
+        throws UnsupportedEncodingException, IOException, ServletException {
+        // Decode using the charset in the request if it exists otherwise
+        // use UTF-8 as this is what all browser implementations use.
+        // The JSON-RPC-Java JavaScript client is ASCII clean so it
+        // although here we can correctly handle data from other clients
+        // that do not escape non ASCII data
+        String charset = request.getCharacterEncoding();
+        if (charset == null) {
+            charset = "UTF-8";
+        }
+        // default POST style
+        BufferedReader in = new BufferedReader(new InputStreamReader(request.getInputStream(), charset));
+        StringWriter data = new StringWriter();
+        // Read the request into charArray
+        char[] buf = new char[4096];
+        int ret;
+        while ((ret = in.read(buf, 0, 4096)) != -1) {
+            data.write(buf, 0, ret);
+        }
+
+        String json = data.toString().trim();
+        try {
+            if (json.startsWith("[")) {
+                JSONArray input = new JSONArray(json);
+                JsonRpc20BatchRequest batchReq = new JsonRpc20BatchRequest(input);
+                for (int i = 0; i < batchReq.getRequests().size(); i++) {
+                    JsonRpc20Result result = batchReq.getBatchResponse().getResponses().get(i);
+                    if (result == null) {
+                        result = invoke(batchReq.getRequests().get(i));
+                        batchReq.getBatchResponse().getResponses().set(i, result);
+                    }
+                }
+                JSONArray responses = batchReq.getBatchResponse().toJSONArray();
+                responses.write(response.getWriter());
+            } else {
+                JSONObject input = new JSONObject(data.toString());
+                if (input.has("jsonrpc")) {
+                    JsonRpc20Request jsonReq = new JsonRpc20Request(input);
+                    JsonRpc20Result jsonResult = invoke(jsonReq);
+                    jsonResult.write(response.getWriter());
+                } else {
+                    JsonRpc10Request jsonReq = new JsonRpc10Request(input);
+                    JsonRpc10Response jsonResult = invoke(jsonReq);
+                    jsonResult.write(response.getWriter());
+                }
+            }
+        } catch (Throwable e) {
+            throw new ServletException(e);
+        }
+    }
+
+    private JsonRpc20Result invoke(JsonRpc20Request request) {
+
+        // invoke the request
+        String method = request.getMethod();
+        Object[] params = request.getParams();
+
+        Object result = null;
+        Operation jsonOperation = findOperation(method);
+
+        // Invoke the get operation on the service implementation
+        Message requestMessage = messageFactory.createMessage();
+        requestMessage.setOperation(jsonOperation);
+
+        requestMessage.getHeaders().put("RequestMessage", request);
+        requestMessage.setBody(params);
+
+        Message responseMessage = null;
+        try {
+
+            //result = wire.invoke(jsonOperation, args);
+            responseMessage = endpoint.getInvocationChain(jsonOperation).getHeadInvoker().invoke(requestMessage);
+        } catch (RuntimeException re) {
+            if (re.getCause() instanceof javax.security.auth.login.LoginException) {
+                throw re;
+            } else {
+                JsonRpc20Error error = new JsonRpc20Error(request.getId(), re);
+                return error;
+            }
+        }
+
+        if (!responseMessage.isFault()) {
+
+            if (jsonOperation.getOutputType().getLogical().size() == 0) {
+                // void operation (json-rpc notification)
+                try {
+                    JsonRpc20Response response = new JsonRpc20Response(request.getId(), null);
+                    return response;
+                } catch (Exception e) {
+                    throw new ServiceRuntimeException("Unable to create JSON response", e);
+                }
+
+            } else {
+                // regular operation returning some value
+                try {
+                    result = responseMessage.getBody();
+                    JsonRpc20Response response = new JsonRpc20Response(request.getId(), result);
+                    //get response to send to client
+                    return response;
+                } catch (Exception e) {
+                    throw new ServiceRuntimeException("Unable to create JSON response", e);
+                }
+            }
+
+        } else {
+            //exception thrown while executing the invocation
+            Throwable exception = (Throwable)responseMessage.getBody();
+
+            JsonRpc20Error error = new JsonRpc20Error(request.getId(), exception);
+            return error;
+        }
+
+    }
+
+    private JsonRpc10Response invoke(JsonRpc10Request request) {
+
+        // invoke the request
+        String method = request.getMethod();
+        Object[] params = request.getParams();
+
+        Object result = null;
+        Operation jsonOperation = findOperation(method);
+
+        // Invoke the get operation on the service implementation
+        Message requestMessage = messageFactory.createMessage();
+        requestMessage.setOperation(jsonOperation);
+
+        requestMessage.getHeaders().put("RequestMessage", request);
+        requestMessage.setBody(params);
+
+        Message responseMessage = null;
+        try {
+
+            //result = wire.invoke(jsonOperation, args);
+            responseMessage = endpoint.getInvocationChain(jsonOperation).getHeadInvoker().invoke(requestMessage);
+        } catch (RuntimeException re) {
+            if (re.getCause() instanceof javax.security.auth.login.LoginException) {
+                throw re;
+            } else {
+                JsonRpc10Response error = new JsonRpc10Response(request.getId(), null, re.toString());
+                return error;
+            }
+        }
+
+        if (!responseMessage.isFault()) {
+
+            if (jsonOperation.getOutputType().getLogical().size() == 0) {
+                // void operation (json-rpc notification)
+                try {
+                    JsonRpc10Response response = new JsonRpc10Response(request.getId(), JSONObject.NULL, null);
+                    return response;
+                } catch (Exception e) {
+                    throw new ServiceRuntimeException("Unable to create JSON response", e);
+                }
+
+            } else {
+                // regular operation returning some value
+                try {
+                    result = responseMessage.getBody();
+                    JsonRpc10Response response = new JsonRpc10Response(request.getId(), result, null);
+                    //get response to send to client
+                    return response;
+                } catch (Exception e) {
+                    throw new ServiceRuntimeException("Unable to create JSON response", e);
+                }
+            }
+
+        } else {
+            //exception thrown while executing the invocation
+            Throwable exception = (Throwable)responseMessage.getBody();
+
+            JsonRpc10Response error =
+                new JsonRpc10Response(request.getId(), null, JsonRpc20Error.stackTrace(exception));
+            return error;
+        }
+
+    }
+
+    /**
+     * Find the operation from the component service contract
+     * @param componentService
+     * @param method
+     * @return
+     */
+    private Operation findOperation(String method) {
+        if (method.contains(".")) {
+            method = method.substring(method.lastIndexOf(".") + 1);
+        }
+
+        List<Operation> operations = endpoint.getComponentServiceInterfaceContract().getInterface().getOperations();
+        //endpoint.getComponentTypeServiceInterfaceContract().getInterface().getOperations();
+        //componentService.getBindingProvider(binding).getBindingInterfaceContract().getInterface().getOperations();
+
+        Operation result = null;
+        for (Operation o : operations) {
+            if (o.isDynamic())
+                return o;
+            if (o.getName().equalsIgnoreCase(method)) {
+                result = o;
+                break;
+            }
+        }
+
+        return result;
+    }
+
+    /**
+     * handles requests for the SMD descriptor for a service
+     */
+    protected void handleSMDRequest(HttpServletRequest request, HttpServletResponse response) throws IOException,
+        UnsupportedEncodingException {
+        String serviceUrl = request.getRequestURL().toString();
+        String smd = JavaToSmd.interfaceToSmd20(serviceInterface, serviceUrl);
+
+        response.setContentType("application/json;charset=utf-8");
+        OutputStream out = response.getOutputStream();
+        byte[] bout = smd.getBytes("UTF-8");
+        out.write(bout);
+        out.flush();
+        out.close();
+    }
+
+}

Propchange: tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpcServlet.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/protocol/JsonRpcServlet.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/provider/JavaToSmd.java
URL: http://svn.apache.org/viewvc/tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/provider/JavaToSmd.java?rev=1178299&r1=1178298&r2=1178299&view=diff
==============================================================================
--- tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/provider/JavaToSmd.java (original)
+++ tuscany/sca-java-2.x/trunk/modules/binding-jsonrpc-runtime/src/main/java/org/apache/tuscany/sca/binding/jsonrpc/provider/JavaToSmd.java Mon Oct  3 05:18:04 2011
@@ -32,9 +32,9 @@ import org.json.JSONObject;
  * 
  * @version $Rev$ $Date$
  */
-class JavaToSmd {
+public class JavaToSmd {
 
-    static String interfaceToSmd(Class<?> klazz, String serviceUrl) {
+    public static String interfaceToSmd(Class<?> klazz, String serviceUrl) {
         try {
             String name = klazz.getSimpleName();
             Method[] methods = klazz.getMethods();
@@ -70,7 +70,7 @@ class JavaToSmd {
 
     }
 
-    static String interfaceToSmd20(Class<?> klazz, String serviceUrl) {
+    public static String interfaceToSmd20(Class<?> klazz, String serviceUrl) {
         try {
             String name = klazz.getSimpleName();
             Method[] methods = klazz.getMethods();