You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@tuscany.apache.org by jm...@apache.org on 2007/03/15 19:32:51 UTC

svn commit: r518719 - in /incubator/tuscany/java/sca/extensions/hessian: ./ binding/src/main/java/org/apache/tuscany/hessian/ binding/src/main/java/org/apache/tuscany/hessian/builder/ binding/src/main/java/org/apache/tuscany/hessian/component/ binding/...

Author: jmarino
Date: Thu Mar 15 11:32:50 2007
New Revision: 518719

URL: http://svn.apache.org/viewvc?view=rev&rev=518719
Log:
start on wire attachement for the Hessian binding

Added:
    incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/InvokerInterceptor.java   (with props)
    incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/builder/
    incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/builder/BindingComponentBuilder.java   (with props)
    incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/component/
    incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/component/BindingComponent.java   (with props)
    incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/component/WireBindException.java   (with props)
    incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/model/
    incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/model/HessianBindingComponentDefinition.java   (with props)
    incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/model/HessianWireSourceDefinition.java   (with props)
    incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/model/HessianWireTargetDefinition.java   (with props)
Removed:
    incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/HessianTargetInvoker.java
Modified:
    incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/DestinationCreationException.java
    incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/InvalidDestinationException.java
    incubator/tuscany/java/sca/extensions/hessian/pom.xml

Modified: incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/DestinationCreationException.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/DestinationCreationException.java?view=diff&rev=518719&r1=518718&r2=518719
==============================================================================
--- incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/DestinationCreationException.java (original)
+++ incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/DestinationCreationException.java Thu Mar 15 11:32:50 2007
@@ -18,32 +18,17 @@
  */
 package org.apache.tuscany.hessian;
 
+import org.apache.tuscany.spi.builder.WiringException;
+
 /**
  * Thrown when an error creating a destination is encountered
  *
  * @version $Rev$ $Date$
  */
-public abstract class DestinationCreationException extends HessianException {
-    public DestinationCreationException() {
-    }
+public abstract class DestinationCreationException extends WiringException {
 
     public DestinationCreationException(String message) {
         super(message);
     }
 
-    public DestinationCreationException(String message, String identifier) {
-        super(message, identifier);
-    }
-
-    public DestinationCreationException(String message, Throwable cause) {
-        super(message, cause);
-    }
-
-    public DestinationCreationException(String message, String identifier, Throwable cause) {
-        super(message, identifier, cause);
-    }
-
-    public DestinationCreationException(Throwable cause) {
-        super(cause);
-    }
 }

Modified: incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/InvalidDestinationException.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/InvalidDestinationException.java?view=diff&rev=518719&r1=518718&r2=518719
==============================================================================
--- incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/InvalidDestinationException.java (original)
+++ incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/InvalidDestinationException.java Thu Mar 15 11:32:50 2007
@@ -1,14 +1,35 @@
+/*
+ * 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.hessian;
 
+import org.apache.tuscany.spi.builder.WiringException;
+
 /**
  * @version $Rev$ $Date$
  */
-public class InvalidDestinationException extends HessianException {
-    public InvalidDestinationException(String message, String identifier) {
-        super(message, identifier);
+public class InvalidDestinationException extends WiringException {
+    public InvalidDestinationException(String message, Throwable cause) {
+        super(message, null, null, cause);
     }
 
-    public InvalidDestinationException(String message, Throwable cause) {
-        super(message, cause);
+    public InvalidDestinationException(String message, String identifier) {
+        super(message, identifier, null, null);
     }
+
 }

Added: incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/InvokerInterceptor.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/InvokerInterceptor.java?view=auto&rev=518719
==============================================================================
--- incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/InvokerInterceptor.java (added)
+++ incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/InvokerInterceptor.java Thu Mar 15 11:32:50 2007
@@ -0,0 +1,67 @@
+/*
+ * 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.hessian;
+
+import org.apache.tuscany.spi.wire.Interceptor;
+import org.apache.tuscany.spi.wire.InvocationRuntimeException;
+import org.apache.tuscany.spi.wire.Message;
+
+/**
+ * Dispatches a service invocation to a Channel
+ *
+ * @version $Rev$ $Date$
+ */
+public class InvokerInterceptor implements Interceptor {
+    private String operation;
+    private Channel channel;
+
+    /**
+     * Creates the interceptor.
+     *
+     * @param operation the service operation the interceptor dispatches for
+     * @param channel   the channel to dispatch to
+     */
+    public InvokerInterceptor(String operation, Channel channel) {
+        this.operation = operation;
+        this.channel = channel;
+    }
+
+    public boolean isOptimizable() {
+        return false;
+    }
+
+    public Message invoke(Message msg) throws InvocationRuntimeException {
+        try {
+            return channel.send(operation, null, msg);
+        } catch (InvocationException e) {
+            msg.setBodyWithFault(e);
+            return msg;
+        }
+    }
+
+    public void setNext(Interceptor next) {
+        throw new IllegalStateException("This interceptor must be the last one in an target interceptor chain");
+    }
+
+    public Interceptor getNext() {
+        return null;
+    }
+
+
+}

Propchange: incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/InvokerInterceptor.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/InvokerInterceptor.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Added: incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/builder/BindingComponentBuilder.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/builder/BindingComponentBuilder.java?view=auto&rev=518719
==============================================================================
--- incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/builder/BindingComponentBuilder.java (added)
+++ incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/builder/BindingComponentBuilder.java Thu Mar 15 11:32:50 2007
@@ -0,0 +1,68 @@
+/*
+ * 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.hessian.builder;
+
+import java.net.URI;
+
+import org.osoa.sca.annotations.Reference;
+
+import org.apache.tuscany.spi.builder.BuilderException;
+import org.apache.tuscany.spi.builder.physical.PhysicalComponentBuilder;
+import org.apache.tuscany.spi.builder.physical.WireAttacher;
+import org.apache.tuscany.spi.component.Component;
+import org.apache.tuscany.spi.wire.Wire;
+
+import org.apache.tuscany.hessian.DestinationCreationException;
+import org.apache.tuscany.hessian.HessianService;
+import org.apache.tuscany.hessian.InvalidDestinationException;
+import org.apache.tuscany.hessian.component.BindingComponent;
+import org.apache.tuscany.hessian.model.HessianBindingComponentDefinition;
+import org.apache.tuscany.hessian.model.HessianWireSourceDefinition;
+import org.apache.tuscany.hessian.model.HessianWireTargetDefinition;
+
+/**
+ * @version $Rev$ $Date$
+ */
+public class BindingComponentBuilder
+    implements PhysicalComponentBuilder<HessianBindingComponentDefinition, BindingComponent>,
+    WireAttacher<BindingComponent, HessianWireSourceDefinition, HessianWireTargetDefinition> {
+
+    private HessianService hessianService;
+
+    public BindingComponentBuilder(@Reference HessianService hessianService) {
+        this.hessianService = hessianService;
+    }
+
+    public BindingComponent build(HessianBindingComponentDefinition definition) throws BuilderException {
+        return new BindingComponent(definition.getComponentId(), hessianService);
+    }
+
+    public void attach(BindingComponent source, Component target, Wire wire, HessianWireSourceDefinition definition)
+        throws DestinationCreationException {
+        URI endpointUri = definition.getEndpointUri();
+        hessianService.createDestination(endpointUri, wire, null); // FIXME classloader
+
+    }
+
+    public void attach(BindingComponent component, Wire wire, HessianWireTargetDefinition definition)
+        throws InvalidDestinationException {
+        URI endpointUri = definition.getEndpointUri();
+        component.bindToEndpoint(endpointUri, wire);
+    }
+}

Propchange: incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/builder/BindingComponentBuilder.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/builder/BindingComponentBuilder.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Added: incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/component/BindingComponent.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/component/BindingComponent.java?view=auto&rev=518719
==============================================================================
--- incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/component/BindingComponent.java (added)
+++ incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/component/BindingComponent.java Thu Mar 15 11:32:50 2007
@@ -0,0 +1,178 @@
+/*
+ * 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.hessian.component;
+
+import java.net.URI;
+import java.util.ArrayList;
+import java.util.List;
+import java.util.Map;
+
+import org.osoa.sca.ComponentContext;
+
+import org.apache.tuscany.spi.AbstractLifecycle;
+import org.apache.tuscany.spi.component.Component;
+import org.apache.tuscany.spi.component.Reference;
+import org.apache.tuscany.spi.component.RegistrationException;
+import org.apache.tuscany.spi.component.ScopeContainer;
+import org.apache.tuscany.spi.component.Service;
+import org.apache.tuscany.spi.component.TargetInvokerCreationException;
+import org.apache.tuscany.spi.event.Event;
+import org.apache.tuscany.spi.event.EventFilter;
+import org.apache.tuscany.spi.event.RuntimeEventListener;
+import org.apache.tuscany.spi.model.Operation;
+import org.apache.tuscany.spi.model.PropertyValue;
+import org.apache.tuscany.spi.model.Scope;
+import org.apache.tuscany.spi.model.physical.PhysicalOperationDefinition;
+import org.apache.tuscany.spi.wire.InvocationChain;
+import org.apache.tuscany.spi.wire.TargetInvoker;
+import org.apache.tuscany.spi.wire.Wire;
+
+import org.apache.tuscany.hessian.Channel;
+import org.apache.tuscany.hessian.DestinationCreationException;
+import org.apache.tuscany.hessian.HessianService;
+import org.apache.tuscany.hessian.InvalidDestinationException;
+import org.apache.tuscany.hessian.InvokerInterceptor;
+
+/**
+ * @version $Rev$ $Date$
+ */
+public class BindingComponent extends AbstractLifecycle implements Component {
+    private URI uri;
+    private HessianService hessianService;
+    private List<URI> endpoints = new ArrayList<URI>();
+
+    public BindingComponent(URI uri, HessianService hessianService) {
+        this.uri = uri;
+        this.hessianService = hessianService;
+    }
+
+    public URI getUri() {
+        return uri;
+    }
+
+    public List<Wire> getWires(String name) {
+        return null;
+    }
+
+    public Map<String, PropertyValue<?>> getDefaultPropertyValues() {
+        return null;
+    }
+
+    public void setDefaultPropertyValues(Map<String, PropertyValue<?>> defaultPropertyValues) {
+
+    }
+
+    public void createEndpoint(URI endpointUri, Wire wire, ClassLoader loader) throws DestinationCreationException {
+        hessianService.createDestination(endpointUri, wire, loader);
+    }
+
+    public void bindToEndpoint(URI endpointUri, Wire wire) throws InvalidDestinationException {
+        Channel channel = hessianService.createChannel(endpointUri);
+        for (Map.Entry<PhysicalOperationDefinition, InvocationChain> entry : wire.getPhysicalInvocationChains()
+            .entrySet()) {
+            String name = entry.getKey().getName();
+            InvokerInterceptor interceptor = new InvokerInterceptor(name, channel);
+            entry.getValue().addInterceptor(interceptor);
+        }
+    }
+
+    public ScopeContainer getScopeContainer() {
+        return null;
+    }
+
+    public ComponentContext getComponentContext() {
+        return null;
+    }
+
+    public void publish(Event object) {
+
+    }
+
+    public void addListener(RuntimeEventListener listener) {
+
+    }
+
+    public void addListener(EventFilter filter, RuntimeEventListener listener) {
+
+    }
+
+    public void removeListener(RuntimeEventListener listener) {
+
+    }
+
+    @Deprecated
+    public void attachWire(Wire wire) {
+    }
+
+    @Deprecated
+    public void attachCallbackWire(Wire wire) {
+    }
+
+    @Deprecated
+    public void attachWires(List<Wire> wires) {
+    }
+
+    @Deprecated
+    public Scope getScope() {
+        return null;
+    }
+
+    @Deprecated
+    public void setScopeContainer(ScopeContainer scopeContainer) {
+
+    }
+
+    @Deprecated
+    public boolean isOptimizable() {
+        return false;
+    }
+
+    @Deprecated
+    public void register(Service service) throws RegistrationException {
+
+    }
+
+    @Deprecated
+    public void register(Reference reference) throws RegistrationException {
+
+    }
+
+    @Deprecated
+    public Service getService(String name) {
+        return null;
+    }
+
+    @Deprecated
+    public Reference getReference(String name) {
+        return null;
+    }
+
+    @Deprecated
+    public TargetInvoker createTargetInvoker(String targetName, Operation operation)
+        throws TargetInvokerCreationException {
+        return null;
+    }
+
+    @Deprecated
+    public TargetInvoker createTargetInvoker(String targetName, PhysicalOperationDefinition operation)
+        throws TargetInvokerCreationException {
+        return null;
+    }
+
+}

Propchange: incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/component/BindingComponent.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/component/BindingComponent.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Added: incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/component/WireBindException.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/component/WireBindException.java?view=auto&rev=518719
==============================================================================
--- incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/component/WireBindException.java (added)
+++ incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/component/WireBindException.java Thu Mar 15 11:32:50 2007
@@ -0,0 +1,31 @@
+/*
+ * 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.hessian.component;
+
+import org.apache.tuscany.hessian.HessianException;
+
+/**
+ * @version $Rev$ $Date$
+ */
+public class WireBindException extends HessianException {
+
+    public WireBindException(Throwable cause) {
+        super(cause);
+    }
+}

Propchange: incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/component/WireBindException.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/component/WireBindException.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Added: incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/model/HessianBindingComponentDefinition.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/model/HessianBindingComponentDefinition.java?view=auto&rev=518719
==============================================================================
--- incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/model/HessianBindingComponentDefinition.java (added)
+++ incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/model/HessianBindingComponentDefinition.java Thu Mar 15 11:32:50 2007
@@ -0,0 +1,10 @@
+package org.apache.tuscany.hessian.model;
+
+import org.apache.tuscany.spi.model.physical.PhysicalComponentDefinition;
+
+/**
+ * @version $Rev$ $Date$
+ */
+public class HessianBindingComponentDefinition extends PhysicalComponentDefinition {
+    
+}

Propchange: incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/model/HessianBindingComponentDefinition.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/model/HessianBindingComponentDefinition.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Added: incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/model/HessianWireSourceDefinition.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/model/HessianWireSourceDefinition.java?view=auto&rev=518719
==============================================================================
--- incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/model/HessianWireSourceDefinition.java (added)
+++ incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/model/HessianWireSourceDefinition.java Thu Mar 15 11:32:50 2007
@@ -0,0 +1,38 @@
+/*
+ * 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.hessian.model;
+
+import java.net.URI;
+
+import org.apache.tuscany.spi.model.physical.PhysicalWireSourceDefinition;
+
+/**
+ * @version $Rev$ $Date$
+ */
+public class HessianWireSourceDefinition extends PhysicalWireSourceDefinition {
+    private URI endpointUri;
+
+    public URI getEndpointUri() {
+        return endpointUri;
+    }
+
+    public void setEndpointUri(URI endpointUri) {
+        this.endpointUri = endpointUri;
+    }
+}

Propchange: incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/model/HessianWireSourceDefinition.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/model/HessianWireSourceDefinition.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Added: incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/model/HessianWireTargetDefinition.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/model/HessianWireTargetDefinition.java?view=auto&rev=518719
==============================================================================
--- incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/model/HessianWireTargetDefinition.java (added)
+++ incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/model/HessianWireTargetDefinition.java Thu Mar 15 11:32:50 2007
@@ -0,0 +1,39 @@
+/*
+ * 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.hessian.model;
+
+import java.net.URI;
+
+import org.apache.tuscany.spi.model.physical.PhysicalWireSourceDefinition;
+import org.apache.tuscany.spi.model.physical.PhysicalWireTargetDefinition;
+
+/**
+ * @version $Rev$ $Date$
+ */
+public class HessianWireTargetDefinition extends PhysicalWireTargetDefinition {
+    private URI endpointUri;
+
+    public URI getEndpointUri() {
+        return endpointUri;
+    }
+
+    public void setEndpointUri(URI endpointUri) {
+        this.endpointUri = endpointUri;
+    }
+}

Propchange: incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/model/HessianWireTargetDefinition.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/tuscany/java/sca/extensions/hessian/binding/src/main/java/org/apache/tuscany/hessian/model/HessianWireTargetDefinition.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: incubator/tuscany/java/sca/extensions/hessian/pom.xml
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/extensions/hessian/pom.xml?view=diff&rev=518719&r1=518718&r2=518719
==============================================================================
--- incubator/tuscany/java/sca/extensions/hessian/pom.xml (original)
+++ incubator/tuscany/java/sca/extensions/hessian/pom.xml Thu Mar 15 11:32:50 2007
@@ -22,7 +22,7 @@
     <parent>
         <groupId>org.apache.tuscany</groupId>
         <artifactId>sca</artifactId>
-        <version>1.0-incubating-SNAPSHOT</version>
+        <version>1.0-incubating</version>
     </parent>
 
     <modelVersion>4.0.0</modelVersion>



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