You are viewing a plain text version of this content. The canonical link for it is here.
Posted to java-dev@axis.apache.org by he...@apache.org on 2005/07/03 12:15:07 UTC

svn commit: r208903 - in /webservices/axis/trunk/java: modules/core/src/org/apache/axis2/transport/ modules/core/src/org/apache/axis2/transport/http/ modules/samples/ modules/samples/src/userguide/clients/ modules/samples/test/org/apache/axis2/engine/ ...

Author: hemapani
Date: Sun Jul  3 03:15:02 2005
New Revision: 208903

URL: http://svn.apache.org/viewcvs?rev=208903&view=rev
Log:
documentation updates and fixing mtom tests

Added:
    webservices/axis/trunk/java/modules/samples/src/userguide/clients/MailClient.java
    webservices/axis/trunk/java/modules/samples/src/userguide/clients/TCPClient.java
    webservices/axis/trunk/java/modules/samples/test/org/apache/axis2/mail/MailetRequestResponceRawXMLTest.java
Removed:
    webservices/axis/trunk/java/modules/samples/test/org/apache/axis2/engine/MailEchoRawXMLTest.java
Modified:
    webservices/axis/trunk/java/modules/core/src/org/apache/axis2/transport/TransportUtils.java
    webservices/axis/trunk/java/modules/core/src/org/apache/axis2/transport/http/HTTPTransportSender.java
    webservices/axis/trunk/java/modules/samples/project.xml
    webservices/axis/trunk/java/modules/samples/test/org/apache/axis2/mtom/EchoRawMTOMLoadTest.java
    webservices/axis/trunk/java/modules/samples/test/org/apache/axis2/mtom/MTOM-enabled-axis2.xml
    webservices/axis/trunk/java/xdocs/tcp-transport.html

Modified: webservices/axis/trunk/java/modules/core/src/org/apache/axis2/transport/TransportUtils.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/modules/core/src/org/apache/axis2/transport/TransportUtils.java?rev=208903&r1=208902&r2=208903&view=diff
==============================================================================
--- webservices/axis/trunk/java/modules/core/src/org/apache/axis2/transport/TransportUtils.java (original)
+++ webservices/axis/trunk/java/modules/core/src/org/apache/axis2/transport/TransportUtils.java Sun Jul  3 03:15:02 2005
@@ -51,6 +51,8 @@
             OperationContext opContext = msgContext.getOperationContext();
             if (opContext != null) {
                 contentType = opContext.getProperty(HTTPConstants.MTOM_RECIVED_CONTENT_TYPE);
+            }else{
+                throw new AxisFault("Operation Context can not be Null");
             }
 
             StAXBuilder builder = null;
@@ -78,7 +80,7 @@
             }
             return envelope;
         } catch (Exception e) {
-            throw new AxisFault(e.getMessage(), e);
+            throw new AxisFault(e);
         }
     }
 

Modified: webservices/axis/trunk/java/modules/core/src/org/apache/axis2/transport/http/HTTPTransportSender.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/modules/core/src/org/apache/axis2/transport/http/HTTPTransportSender.java?rev=208903&r1=208902&r2=208903&view=diff
==============================================================================
--- webservices/axis/trunk/java/modules/core/src/org/apache/axis2/transport/http/HTTPTransportSender.java (original)
+++ webservices/axis/trunk/java/modules/core/src/org/apache/axis2/transport/http/HTTPTransportSender.java Sun Jul  3 03:15:02 2005
@@ -184,7 +184,6 @@
                     if(opContext != null){
                         opContext.setProperty(HTTPConstants.MTOM_RECIVED_CONTENT_TYPE,contentType);
                     }
-                    
                 }
             }
         } catch (AxisFault e) {

Modified: webservices/axis/trunk/java/modules/samples/project.xml
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/modules/samples/project.xml?rev=208903&r1=208902&r2=208903&view=diff
==============================================================================
--- webservices/axis/trunk/java/modules/samples/project.xml (original)
+++ webservices/axis/trunk/java/modules/samples/project.xml Sun Jul  3 03:15:02 2005
@@ -132,14 +132,16 @@
         <exclude>**/*Abstract*.java</exclude>
 	    <exclude>**/*Util*.java</exclude>
 		<exclude>**/*InteropStubTest.java</exclude>
-		<exclude>**/*MailEchoRawXMLTest.java</exclude> 
+		<exclude>**/*EchoRawXMLChunckedTest.java</exclude>
+		<exclude>**org/apache/axis2/mail/*.java</exclude>
+		<exclude>**org/apache/axis2/mtom/*.java</exclude>
+<!--		<exclude>**/*MailEchoRawXMLTest.java</exclude> 
 		<exclude>**/*MailOneWayRawXMLTest.java</exclude> 
 		<exclude>**/*MailRequestResponseRawXMLTest.java</exclude> 
-		<exclude>**/*EchoRawXMLChunckedTest.java</exclude> 
-		<!-- <exclude>**/*CommonsHTTPEchoRawXMLTest.java</exclude>  -->
+     	  <exclude>**/*CommonsHTTPEchoRawXMLTest.java</exclude>  
 		<exclude>**/*EchoRawMTOMTest.java</exclude>
-<exclude>**/*EchoRawMTOMLoadTest.java</exclude>
-		<exclude>**/*EchoRawMTOMToBase64Test.java</exclude> 
+        <exclude>**/*EchoRawMTOMLoadTest.java</exclude>
+		<exclude>**/*EchoRawMTOMToBase64Test.java</exclude>  -->
       </excludes>
      <includes>
         <include>**/*Test.java</include>

Added: webservices/axis/trunk/java/modules/samples/src/userguide/clients/MailClient.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/modules/samples/src/userguide/clients/MailClient.java?rev=208903&view=auto
==============================================================================
--- webservices/axis/trunk/java/modules/samples/src/userguide/clients/MailClient.java (added)
+++ webservices/axis/trunk/java/modules/samples/src/userguide/clients/MailClient.java Sun Jul  3 03:15:02 2005
@@ -0,0 +1,52 @@
+/*
+ * Copyright 2004,2005 The Apache Software Foundation.
+ *
+ * Licensed 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 userguide.clients;
+
+import org.apache.axis2.Constants;
+import org.apache.axis2.addressing.AddressingConstants;
+import org.apache.axis2.addressing.EndpointReference;
+import org.apache.axis2.clientapi.MessageSender;
+import org.apache.axis2.engine.AxisFault;
+import org.apache.axis2.om.OMAbstractFactory;
+import org.apache.axis2.om.OMElement;
+import org.apache.axis2.om.OMFactory;
+import org.apache.axis2.om.OMNamespace;
+
+/**
+ * This is a Client progam that accesses 'MyService' web service in Axis2 samples 
+ */
+public class MailClient {
+
+    private static String toEpr = "http://localhost:8080/axis2/services/MyService";
+
+    public static void main(String[] args) throws AxisFault {
+        MessageSender msgSender = new MessageSender();
+        msgSender.setTo(new EndpointReference(AddressingConstants.WSA_TO, toEpr));
+        msgSender.setSenderTransport(Constants.TRANSPORT_MAIL);
+        msgSender.send("echo", getPayload());
+    }
+
+    private static OMElement getPayload() {
+        OMFactory fac = OMAbstractFactory.getOMFactory();
+        OMNamespace omNs = fac.createOMNamespace("http://example1.org/example1", "example1");
+        OMElement method = fac.createOMElement("echo", omNs);
+        OMElement value = fac.createOMElement("Text", omNs);
+        value.addChild(fac.createText(value, "Axis2 Echo String "));
+        method.addChild(value);
+
+        return method;
+    }
+}

Added: webservices/axis/trunk/java/modules/samples/src/userguide/clients/TCPClient.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/modules/samples/src/userguide/clients/TCPClient.java?rev=208903&view=auto
==============================================================================
--- webservices/axis/trunk/java/modules/samples/src/userguide/clients/TCPClient.java (added)
+++ webservices/axis/trunk/java/modules/samples/src/userguide/clients/TCPClient.java Sun Jul  3 03:15:02 2005
@@ -0,0 +1,70 @@
+/*
+ * Copyright 2004,2005 The Apache Software Foundation.
+ *
+ * Licensed 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 userguide.clients;
+
+import org.apache.axis2.Constants;
+import org.apache.axis2.addressing.AddressingConstants;
+import org.apache.axis2.addressing.EndpointReference;
+import org.apache.axis2.clientapi.Call;
+import org.apache.axis2.engine.AxisFault;
+import org.apache.axis2.om.*;
+
+import javax.xml.namespace.QName;
+import javax.xml.stream.FactoryConfigurationError;
+import javax.xml.stream.XMLOutputFactory;
+import javax.xml.stream.XMLStreamException;
+import javax.xml.stream.XMLStreamWriter;
+
+/**
+ * This is a Client progam that accesses 'MyService' web service in Axis2 samples 
+ */
+public class TCPClient {
+
+	private static String toEpr = "tcp://localhost:8080/axis2/services/MyService";
+	
+	public static void main(String[] args) throws AxisFault {
+		
+			Call  call = new Call();
+			call.setTo(new EndpointReference(AddressingConstants.WSA_TO,toEpr));
+			call.setTransportInfo(Constants.TRANSPORT_TCP,Constants.TRANSPORT_TCP,false);
+			call.engageModule(new QName(Constants.MODULE_ADDRESSING));
+			
+			OMElement result = call.invokeBlocking("echo", getPayload());
+		
+			try {
+				XMLStreamWriter writer = XMLOutputFactory.newInstance().createXMLStreamWriter(System.out);
+				result.serializeWithCache(new OMOutput(writer));
+				writer.flush();
+			} catch (XMLStreamException e) {
+				e.printStackTrace();
+			} catch (FactoryConfigurationError e) {
+				e.printStackTrace();
+			}
+	}
+	
+	
+	private static OMElement getPayload() {
+		OMFactory fac = OMAbstractFactory.getOMFactory();
+		OMNamespace omNs = fac.createOMNamespace(
+				"http://example1.org/example1", "example1");
+		OMElement method = fac.createOMElement("echo", omNs);
+		OMElement value = fac.createOMElement("Text", omNs);
+		value.addChild(fac.createText(value, "Axis2 Echo String "));
+		method.addChild(value);
+
+		return method;
+	}
+}

Added: webservices/axis/trunk/java/modules/samples/test/org/apache/axis2/mail/MailetRequestResponceRawXMLTest.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/modules/samples/test/org/apache/axis2/mail/MailetRequestResponceRawXMLTest.java?rev=208903&view=auto
==============================================================================
--- webservices/axis/trunk/java/modules/samples/test/org/apache/axis2/mail/MailetRequestResponceRawXMLTest.java (added)
+++ webservices/axis/trunk/java/modules/samples/test/org/apache/axis2/mail/MailetRequestResponceRawXMLTest.java Sun Jul  3 03:15:02 2005
@@ -0,0 +1,227 @@
+    /*
+     * Copyright 2004,2005 The Apache Software Foundation.
+     * 
+     * Licensed 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.axis2.mail;
+
+
+import javax.xml.namespace.QName;
+import javax.xml.stream.XMLOutputFactory;
+import javax.xml.stream.XMLStreamException;
+
+import junit.framework.TestCase;
+
+import org.apache.axis2.Constants;
+import org.apache.axis2.addressing.AddressingConstants;
+import org.apache.axis2.addressing.EndpointReference;
+import org.apache.axis2.clientapi.AsyncResult;
+import org.apache.axis2.clientapi.Callback;
+import org.apache.axis2.context.ConfigurationContext;
+import org.apache.axis2.context.ConfigurationContextFactory;
+import org.apache.axis2.context.MessageContext;
+import org.apache.axis2.context.ServiceContext;
+import org.apache.axis2.description.OperationDescription;
+import org.apache.axis2.description.ParameterImpl;
+import org.apache.axis2.description.ServiceDescription;
+import org.apache.axis2.description.TransportInDescription;
+import org.apache.axis2.description.TransportOutDescription;
+import org.apache.axis2.engine.AxisConfiguration;
+import org.apache.axis2.engine.AxisFault;
+import org.apache.axis2.engine.Echo;
+import org.apache.axis2.engine.MessageReceiver;
+import org.apache.axis2.om.OMAbstractFactory;
+import org.apache.axis2.om.OMElement;
+import org.apache.axis2.om.OMFactory;
+import org.apache.axis2.om.OMNamespace;
+import org.apache.axis2.om.OMOutput;
+import org.apache.axis2.soap.SOAPEnvelope;
+import org.apache.axis2.transport.mail.server.MailConstants;
+import org.apache.axis2.transport.mail.MailTransportSender;
+import org.apache.axis2.transport.mail.SimpleMailListener;
+import org.apache.axis2.transport.mail.server.MailServer;
+import org.apache.axis2.util.Utils;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+
+/**
+ * This will use the In out functionality to test the mailet functionality. This code was
+ * based on the code on the MailRequestResponceRawXMLTest.java.
+ * 
+ * @author Chamil Thanthrimudalige <ch...@gmail.com>
+ * 
+  */
+public class MailetRequestResponceRawXMLTest extends TestCase {
+        private EndpointReference targetEPR =
+            new EndpointReference(
+                AddressingConstants.WSA_TO,
+                "axis2-server@127.0.0.1" + "/axis/services/EchoXMLService/echoOMElement");
+        private Log log = LogFactory.getLog(getClass());
+        private QName serviceName = new QName("EchoXMLService");
+        private QName operationName = new QName("echoOMElement");
+        private QName transportName = new QName("http://localhost/my", "NullTransport");
+
+        private AxisConfiguration engineRegistry;
+        private MessageContext mc;
+
+        private SOAPEnvelope envelope;
+
+        private boolean finish = false;
+
+        public MailetRequestResponceRawXMLTest() {
+            super(MailetRequestResponceRawXMLTest.class.getName());
+        }
+
+        public MailetRequestResponceRawXMLTest(String testName) {
+            super(testName);
+        }
+
+        protected void setUp() throws Exception {
+            ConfigurationContext configContext = createServerConfigurationContext(); 
+            MailServer server = new MailServer(configContext, MailConstants.POP_SERVER_PORT, MailConstants.SMTP_SERVER_PORT);
+            configContext.getAxisConfiguration().engageModule(new QName(Constants.MODULE_ADDRESSING));
+            ServiceDescription service =
+                Utils.createSimpleService(serviceName, Echo.class.getName(), operationName);
+            configContext.getAxisConfiguration().addService(service);
+            Utils.resolvePhases(configContext.getAxisConfiguration(), service);
+            ServiceContext serviceContext = configContext.createServiceContext(serviceName);
+        }
+
+        protected void tearDown() throws Exception {
+        }
+
+        private OMElement createEnvelope() {
+            OMFactory fac = OMAbstractFactory.getOMFactory();
+            OMNamespace omNs = fac.createOMNamespace("http://localhost/my", "my");
+            OMElement method = fac.createOMElement("echoOMElement", omNs);
+            OMElement value = fac.createOMElement("myValue", omNs);
+            value.addChild(fac.createText(value, "Isaac Assimov, the foundation Sega"));
+            method.addChild(value);
+
+            return method;
+        }
+
+        public void testEchoXMLCompleteASync() throws Exception {
+
+            ConfigurationContext configContext = createClientConfigurationContext();
+            ServiceDescription service = new ServiceDescription(serviceName);
+            OperationDescription operation = new OperationDescription(operationName);
+            operation.setMessageReciever(new MessageReceiver() {
+                public void recieve(MessageContext messgeCtx) throws AxisFault {
+                    envelope = messgeCtx.getEnvelope();
+                }
+            });
+            service.addOperation(operation);
+            configContext.getAxisConfiguration().addService(service);
+            Utils.resolvePhases(configContext.getAxisConfiguration(), service);
+            ServiceContext serviceContext = configContext.createServiceContext(serviceName);
+
+            org.apache.axis2.clientapi.Call call = new org.apache.axis2.clientapi.Call(serviceContext);
+            call.engageModule(new QName(Constants.MODULE_ADDRESSING));
+
+                call.setTo(targetEPR);
+                call.setTransportInfo(Constants.TRANSPORT_MAIL, Constants.TRANSPORT_MAIL, true);
+                Callback callback = new Callback() {
+                    public void onComplete(AsyncResult result) {
+                        try {
+                            result.getResponseEnvelope().serialize(
+                                new OMOutput(XMLOutputFactory.newInstance().createXMLStreamWriter(System.out)));
+                        } catch (XMLStreamException e) {
+                            reportError(e);
+                        } finally {
+                            finish = true;
+                        }
+                    }
+
+                    public void reportError(Exception e) {
+                        e.printStackTrace();
+                        finish = true;
+                    }
+                };
+
+                call.invokeNonBlocking(operationName.getLocalPart(), createEnvelope(), callback);
+                int index = 0;
+                while (!finish) {
+                    Thread.sleep(1000);
+                    index++;
+                    if (index > 10) {
+                        throw new AxisFault("Async response is taking too long[10s+]. Server is being shut down.");
+                    }
+                }
+                call.close();
+
+        }
+        public ConfigurationContext createServerConfigurationContext() throws Exception {
+            ConfigurationContextFactory builder = new ConfigurationContextFactory();
+            ConfigurationContext configContext =
+                builder.buildConfigurationContext(org.apache.axis2.Constants.TESTING_REPOSITORY);
+
+            TransportInDescription transportIn =
+                new TransportInDescription(new QName(Constants.TRANSPORT_MAIL));
+            transportIn.addParameter(new ParameterImpl("transport.mail.pop3.host", "127.0.0.1"));
+            transportIn.addParameter(new ParameterImpl("transport.mail.pop3.user", "server@127.0.0.1"));
+            transportIn.addParameter(new ParameterImpl("transport.mail.pop3.password", "axis2"));
+            transportIn.addParameter(new ParameterImpl("transport.mail.pop3.port", "1134"));
+            transportIn.addParameter(
+                new ParameterImpl("transport.mail.replyToAddress", "foo@127.0.0.1"));
+            transportIn.setReciver(new SimpleMailListener());
+            transportIn.getReciever().init(configContext,transportIn);
+
+            TransportOutDescription transportOut =
+                new TransportOutDescription(new QName(Constants.TRANSPORT_MAIL));
+
+            transportOut.addParameter(new ParameterImpl("transport.mail.smtp.host", "127.0.0.1"));
+            transportOut.addParameter(new ParameterImpl("transport.mail.smtp.user", "server"));
+            transportOut.addParameter(new ParameterImpl("transport.mail.smtp.password", "axis2"));
+            transportOut.addParameter(new ParameterImpl("transport.mail.smtp.port", "1049"));
+            transportOut.setSender(new MailTransportSender());
+            transportOut.getSender().init(configContext,transportOut);
+
+            configContext.getAxisConfiguration().addTransportIn(transportIn);
+            configContext.getAxisConfiguration().addTransportOut(transportOut);
+            return configContext;
+        }
+
+        public ConfigurationContext createClientConfigurationContext() throws Exception {
+            ConfigurationContextFactory builder = new ConfigurationContextFactory();
+            ConfigurationContext configContext =
+                builder.buildConfigurationContext(org.apache.axis2.Constants.TESTING_REPOSITORY);
+
+            TransportInDescription transportIn =
+                new TransportInDescription(new QName(Constants.TRANSPORT_MAIL));
+            transportIn.addParameter(new ParameterImpl("transport.mail.pop3.host", "127.0.0.1"));
+            transportIn.addParameter(new ParameterImpl("transport.mail.pop3.user", "client@127.0.0.1"));
+            transportIn.addParameter(new ParameterImpl("transport.mail.pop3.password", "axis2"));
+            transportIn.addParameter(new ParameterImpl("transport.mail.pop3.port", "1134"));
+            transportIn.addParameter(
+                new ParameterImpl("transport.mail.replyToAddress", "client@127.0.0.1"));
+            transportIn.setReciver(new SimpleMailListener());
+            transportIn.getReciever().init(configContext,transportIn);
+
+            TransportOutDescription transportOut =
+                new TransportOutDescription(new QName(Constants.TRANSPORT_MAIL));
+
+            transportOut.addParameter(new ParameterImpl("transport.mail.smtp.host", "127.0.0.1"));
+            transportOut.addParameter(new ParameterImpl("transport.mail.smtp.user", "client"));
+            transportOut.addParameter(new ParameterImpl("transport.mail.smtp.password", "axis2"));
+            transportOut.addParameter(new ParameterImpl("transport.mail.smtp.port", "1049"));
+            transportOut.setSender(new MailTransportSender());
+            transportOut.getSender().init(configContext,transportOut);
+
+            configContext.getAxisConfiguration().addTransportIn(transportIn);
+            configContext.getAxisConfiguration().addTransportOut(transportOut);
+            return configContext;
+        }
+
+
+}

Modified: webservices/axis/trunk/java/modules/samples/test/org/apache/axis2/mtom/EchoRawMTOMLoadTest.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/modules/samples/test/org/apache/axis2/mtom/EchoRawMTOMLoadTest.java?rev=208903&r1=208902&r2=208903&view=diff
==============================================================================
--- webservices/axis/trunk/java/modules/samples/test/org/apache/axis2/mtom/EchoRawMTOMLoadTest.java (original)
+++ webservices/axis/trunk/java/modules/samples/test/org/apache/axis2/mtom/EchoRawMTOMLoadTest.java Sun Jul  3 03:15:02 2005
@@ -100,7 +100,7 @@
 		OMElement data = fac.createOMElement("data", omNs);
 		byte[] byteArray = new byte[] { 13, 56, 65, 32, 12, 12, 7, -3, -2, -1,
 				98 };
-		for (int i = 0; i <1; i++) {
+		for (int i = 0; i <4; i++) {
 			OMElement subData = fac.createOMElement("subData", omNs);
 			DataHandler dataHandler = new DataHandler(new ByteArrayDataSource(
 					byteArray));
@@ -108,7 +108,7 @@
 			//OMText textData = new OMTextImpl("Thilina Gunarathne");
 			subData.addChild(textData);
 			data.addChild(subData);
-			System.out.println("Creating blobs "+i);
+			//System.out.println("Creating blobs "+i);
 		}
 		
 		rpcWrapEle.addChild(data);

Modified: webservices/axis/trunk/java/modules/samples/test/org/apache/axis2/mtom/MTOM-enabled-axis2.xml
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/modules/samples/test/org/apache/axis2/mtom/MTOM-enabled-axis2.xml?rev=208903&r1=208902&r2=208903&view=diff
==============================================================================
--- webservices/axis/trunk/java/modules/samples/test/org/apache/axis2/mtom/MTOM-enabled-axis2.xml (original)
+++ webservices/axis/trunk/java/modules/samples/test/org/apache/axis2/mtom/MTOM-enabled-axis2.xml Sun Jul  3 03:15:02 2005
@@ -4,8 +4,7 @@
    <!-- ================================================= -->
     <parameter name="hotdeployment" locked="xsd:false">true</parameter>
     <parameter name="hotupdate" locked="xsd:false">false</parameter>
-    <parameter name="enableMTOM" locked="xsd:false">false</parameter>
-    <parameter name="attachmentDIR" locked="xsd:false">C:\temp</parameter>
+    <parameter name="enableMTOM" locked="xsd:false">true</parameter>
     <parameter name="cacheAttachments" locked="xsd:false">false</parameter>
     <!-- Uncomment this to enable REST support -->
 <!--    <parameter name="eanbleREST" locked="xsd:false">true</parameter>-->

Modified: webservices/axis/trunk/java/xdocs/tcp-transport.html
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/xdocs/tcp-transport.html?rev=208903&r1=208902&r2=208903&view=diff
==============================================================================
--- webservices/axis/trunk/java/xdocs/tcp-transport.html (original)
+++ webservices/axis/trunk/java/xdocs/tcp-transport.html Sun Jul  3 03:15:02 2005
@@ -44,6 +44,11 @@
 <p>The method to note is setTransportInfo that accepts sender transport, Listener transport and should the return path of the TCP Channel need to be used. It is good Idea to engage the addressing module to make the SOAP Message self contained. Only other option I can think of is to use the URI of the first child of the SOAP Body to dispatch the service. The
 Parameter is of the type <a href="faq.html#a2">OMElement</a>, the XML represntation of Axis2.</p>
 
+<h2>Sample</h2>
+<p>Sample for a TCP Client can be found from the samples/userguide/clients/TCPClient.java in the binary distribution, this accsess the same web service explained in the 
+userguide. To try the client first starts the TCPServer with the same repository used for the userguide samples. Since sample is already deployed in the 
+repository while trying the userguide it will be automatically avalible.</p>
+
 <h2>Advanced Topics</h2>
 <p>Axis2 TCP transport has two parts, a transport Listener for receiving the Messages and transport Sender 
 to send the SOAP Messages. Axis2 installation has both the components built in to itself  by default.