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/02/10 07:33:05 UTC

svn commit: r153171 [1/3] - in webservices/axis/trunk/java/dev/scratch/prototype2/src: java/org/apache/axis/clientapi/ java/org/apache/axis/context/ java/org/apache/axis/deployment/ java/org/apache/axis/deployment/repository/utill/ java/org/apache/axis/description/ java/org/apache/axis/engine/ java/org/apache/axis/handlers/ java/org/apache/axis/impl/ java/org/apache/axis/om/impl/ java/org/apache/axis/om/impl/llom/ java/org/apache/axis/om/impl/llom/builder/ java/org/apache/axis/om/impl/llom/exception/ java/org/apache/axis/om/impl/llom/factory/ java/org/apache/axis/om/impl/llom/serialize/ java/org/apache/axis/om/impl/llom/traverse/ java/org/apache/axis/om/impl/llom/util/ java/org/apache/axis/phaseresolver/ java/org/apache/axis/providers/ java/org/apache/axis/receivers/ java/org/apache/axis/transport/ java/org/apache/axis/transport/http/ java/org/apache/axis/transport/tcp/ samples/encoding/sample1/src/org/apache/axis/sample/echo/ test/org/apache/axis/clientapi/ test/org/apache/axis/deployment/ test/org/apache/axis/description/ test/org/apache/axis/engine/ test/org/apache/axis/integration/ test/org/apache/axis/misc/ test/org/apache/axis/om/ test/org/apache/axis/om/builder/ test/org/apache/axis/om/factory/ test/org/apache/axis/om/impl/builder/ test/org/apache/axis/om/impl/seriliazer/ test/org/apache/axis/om/impl/streamwrapper/ test/org/apache/axis/om/impl/traverse/

Author: hemapani
Date: Wed Feb  9 22:32:42 2005
New Revision: 153171

URL: http://svn.apache.org/viewcvs?view=rev&rev=153171
Log:
initial refactoring of the code accroding to the IRC chat, this this first one another one comping shortly

Added:
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/context/SimpleSessionContext.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/AxisService.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/FlowImpl.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/FlowIncludeImpl.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/ParameterImpl.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/ParameterIncludeImpl.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/PhasesIncludeImpl.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/SimpleAxisOperationImpl.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/handlers/
      - copied from r153162, webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/impl/handlers/
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/
      - copied from r153162, webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/impl/llom/
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/providers/
      - copied from r153162, webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/impl/providers/
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/receivers/
      - copied from r153162, webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/impl/receivers/
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/transport/http/
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/transport/http/AxisServlet.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/transport/http/HTTPConstants.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/transport/http/HTTPTransportSender.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/transport/http/NonBlockingBufferedInputStream.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/transport/http/SimpleHTTPReceiver.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/transport/tcp/
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/transport/tcp/TCPTransportReceiver.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/transport/tcp/TCPTrasnportSender.java
Removed:
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/impl/
Modified:
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/clientapi/AbstractCall.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/clientapi/Call.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/context/MessageContext.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/deployment/DeploymentEngine.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/deployment/DeploymentParser.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/deployment/repository/utill/UnZipJAR.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/AxisGlobal.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/AxisModule.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/AxisTransport.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/HandlerMetaData.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/AxisEngine.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/Dispatcher.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/EngineRegistry.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/EngineRegistryFactory.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/Handler.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/Phase.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/Provider.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/ReceiverLocator.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/TransportSenderLocator.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/handlers/AbstractHandler.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/handlers/OpNameFinder.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMAttributeImpl.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMDocument.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMElementImpl.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMNamedNodeImpl.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMNamespaceImpl.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMNavigator.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMNodeImpl.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMStAXWrapper.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMTextImpl.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPBodyImpl.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPEnvelopeImpl.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPFaultImpl.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPHeaderBlockImpl.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPHeaderImpl.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/builder/ObjectToOMBuilder.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/builder/StAXBuilder.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/builder/StAXOMBuilder.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/builder/StAXSOAPModelBuilder.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/exception/OMBuilderException.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/exception/OMSerializerException.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/exception/OMStreamingException.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/factory/OMLinkedListImplFactory.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/factory/OMXMLBuilderFactory.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/serialize/StreamingOMSerializer.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/traverse/OMChildrenIterator.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/traverse/OMChildrenQNameIterator.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/traverse/OMChildrenWithSpecificAttributeIterator.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/util/StreamWriterToContentHandlerConverter.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/phaseresolver/PhaseHolder.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/phaseresolver/PhaseMetaData.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/phaseresolver/PhaseResolver.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/providers/AbstractProvider.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/providers/RawXMLProvider.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/providers/SimpleJavaProvider.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/receivers/INReceiver.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/receivers/InOutAsyncReceiver.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/receivers/InOutSyncReceiver.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/transport/AbstractTransportReceiver.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/transport/AbstractTransportSender.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/samples/encoding/sample1/src/org/apache/axis/sample/echo/EchoProvider.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/samples/encoding/sample1/src/org/apache/axis/sample/echo/EchoStructEncoder.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/clientapi/TestSendReceive.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/clientapi/TestSendReceiveAsync.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/deployment/BadServiceXMLTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/deployment/BuildERWithDeploymentTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/description/MockFlow.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/description/RegistryTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/description/SpeakingHandler.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/description/SpeakingHandler1.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/description/SpeakingProvider.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/engine/CallUnregisterdServiceTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/engine/EchoRawXMLTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/engine/EchoTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/engine/EngineTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/engine/EngineUtils.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/engine/HandlerFaliureTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/engine/MessageContextTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/engine/MessageWithServerTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/engine/SimpleAxisServerTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/integration/EchoTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/integration/UtilServer.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/misc/MiscTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/om/BadInputTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/om/CompareOMWithDOMTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/om/IteratorTester.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/om/OMChildrenQNameIteratorTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/om/OMHeaderTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/om/OMNavigatorTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/om/OMTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/om/OMTestCase.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/om/OMTestUtils.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/om/SOAPFaultTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/om/builder/ObjectToOMBuilderTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/om/factory/OMLinkedListImplFactoryTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/om/impl/builder/StAXOMBuilderTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/om/impl/seriliazer/ElementSerializerTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/om/impl/seriliazer/OMSerailizerTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/om/impl/streamwrapper/OMStaxStreamingWrapperTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/om/impl/streamwrapper/OmStAXBuilderTest.java
    webservices/axis/trunk/java/dev/scratch/prototype2/src/test/org/apache/axis/om/impl/traverse/OMChildrenWithSpecificAttributeIteratorTest.java

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/clientapi/AbstractCall.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/clientapi/AbstractCall.java?view=diff&r1=153170&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/clientapi/AbstractCall.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/clientapi/AbstractCall.java Wed Feb  9 22:32:42 2005
@@ -25,10 +25,10 @@
 import org.apache.axis.context.MessageContext;
 import org.apache.axis.engine.AxisFault;
 import org.apache.axis.engine.EngineRegistry;
-import org.apache.axis.impl.llom.builder.StAXBuilder;
-import org.apache.axis.impl.llom.builder.StAXSOAPModelBuilder;
 import org.apache.axis.om.OMFactory;
 import org.apache.axis.om.SOAPEnvelope;
+import org.apache.axis.om.impl.llom.builder.StAXBuilder;
+import org.apache.axis.om.impl.llom.builder.StAXSOAPModelBuilder;
 
 
 public abstract class AbstractCall {

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/clientapi/Call.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/clientapi/Call.java?view=diff&r1=153170&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/clientapi/Call.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/clientapi/Call.java Wed Feb  9 22:32:42 2005
@@ -6,8 +6,8 @@
 import org.apache.axis.engine.AxisEngine;
 import org.apache.axis.engine.AxisFault;
 import org.apache.axis.engine.EngineRegistry;
+import org.apache.axis.engine.EngineRegistryImpl;
 import org.apache.axis.engine.TransportSenderLocator;
-import org.apache.axis.impl.engine.EngineRegistryImpl;
 import org.apache.axis.om.OMException;
 import org.apache.axis.om.SOAPEnvelope;
 import org.apache.commons.logging.Log;

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/context/MessageContext.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/context/MessageContext.java?view=diff&r1=153170&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/context/MessageContext.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/context/MessageContext.java Wed Feb  9 22:32:42 2005
@@ -19,13 +19,12 @@
 import org.apache.axis.addressing.EndpointReference;
 import org.apache.axis.addressing.miheaders.RelatesTo;
 import org.apache.axis.description.AxisOperation;
+import org.apache.axis.description.AxisService;
 import org.apache.axis.description.AxisTransport;
 import org.apache.axis.engine.AxisFault;
 import org.apache.axis.engine.Constants;
 import org.apache.axis.engine.EngineRegistry;
 import org.apache.axis.engine.ExecutionChain;
-import org.apache.axis.impl.context.SimpleSessionContext;
-import org.apache.axis.impl.description.AxisService;
 import org.apache.axis.om.OMElement;
 import org.apache.axis.om.SOAPEnvelope;
 

Added: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/context/SimpleSessionContext.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/context/SimpleSessionContext.java?view=auto&rev=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/context/SimpleSessionContext.java (added)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/context/SimpleSessionContext.java Wed Feb  9 22:32:42 2005
@@ -0,0 +1,32 @@
+/*
+ * Copyright 2003,2004 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.axis.context;
+
+
+import java.util.HashMap;
+
+public class SimpleSessionContext implements SessionContext {
+    private HashMap map = new HashMap();
+
+    public Object get(Object key) {
+        return map.get(key);
+    }
+
+    public void put(Object key, Object obj) {
+        map.put(key, obj);
+
+    }
+}

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/deployment/DeploymentEngine.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/deployment/DeploymentEngine.java?view=diff&r1=153170&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/deployment/DeploymentEngine.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/deployment/DeploymentEngine.java Wed Feb  9 22:32:42 2005
@@ -8,14 +8,14 @@
 import org.apache.axis.deployment.scheduler.SchedulerTask;
 import org.apache.axis.description.AxisGlobal;
 import org.apache.axis.description.AxisModule;
+import org.apache.axis.description.AxisService;
 import org.apache.axis.description.Flow;
 import org.apache.axis.description.HandlerMetaData;
 import org.apache.axis.engine.AxisFault;
 import org.apache.axis.engine.EngineRegistry;
+import org.apache.axis.engine.EngineRegistryImpl;
 import org.apache.axis.engine.Handler;
 import org.apache.axis.engine.Provider;
-import org.apache.axis.impl.description.AxisService;
-import org.apache.axis.impl.engine.EngineRegistryImpl;
 import org.apache.axis.phaseresolver.PhaseException;
 import org.apache.axis.phaseresolver.PhaseResolver;
 import org.apache.commons.logging.Log;

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/deployment/DeploymentParser.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/deployment/DeploymentParser.java?view=diff&r1=153170&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/deployment/DeploymentParser.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/deployment/DeploymentParser.java Wed Feb  9 22:32:42 2005
@@ -2,11 +2,7 @@
 
 import org.apache.axis.description.*;
 import org.apache.axis.engine.AxisFault;
-import org.apache.axis.impl.description.AxisService;
-import org.apache.axis.impl.description.FlowImpl;
-import org.apache.axis.impl.description.ParameterImpl;
-import org.apache.axis.impl.description.SimpleAxisOperationImpl;
-import org.apache.axis.impl.engine.EngineRegistryImpl;
+import org.apache.axis.engine.EngineRegistryImpl;
 import org.apache.axis.phaseresolver.PhaseException;
 
 import javax.xml.namespace.QName;

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/deployment/repository/utill/UnZipJAR.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/deployment/repository/utill/UnZipJAR.java?view=diff&r1=153170&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/deployment/repository/utill/UnZipJAR.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/deployment/repository/utill/UnZipJAR.java Wed Feb  9 22:32:42 2005
@@ -21,7 +21,7 @@
 import org.apache.axis.deployment.DeploymentException;
 import org.apache.axis.deployment.DeploymentParser;
 import org.apache.axis.description.AxisModule;
-import org.apache.axis.impl.description.AxisService;
+import org.apache.axis.description.AxisService;
 
 import java.io.FileInputStream;
 import java.util.zip.ZipEntry;

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/AxisGlobal.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/AxisGlobal.java?view=diff&r1=153170&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/AxisGlobal.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/AxisGlobal.java Wed Feb  9 22:32:42 2005
@@ -16,8 +16,6 @@
 package org.apache.axis.description;
 
 import org.apache.axis.engine.AxisFault;
-import org.apache.axis.impl.description.ParameterIncludeImpl;
-import org.apache.axis.impl.description.PhasesIncludeImpl;
 
 import javax.xml.namespace.QName;
 import java.util.ArrayList;

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/AxisModule.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/AxisModule.java?view=diff&r1=153170&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/AxisModule.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/AxisModule.java Wed Feb  9 22:32:42 2005
@@ -15,8 +15,6 @@
  */
 package org.apache.axis.description;
 
-import org.apache.axis.impl.description.FlowIncludeImpl;
-import org.apache.axis.impl.description.ParameterIncludeImpl;
 
 import javax.xml.namespace.QName;
 

Added: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/AxisService.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/AxisService.java?view=auto&rev=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/AxisService.java (added)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/AxisService.java Wed Feb  9 22:32:42 2005
@@ -0,0 +1,239 @@
+/*
+ * Copyright 2001-2004 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.axis.description;
+
+import java.util.ArrayList;
+import java.util.Collection;
+import java.util.HashMap;
+
+import javax.swing.text.Style;
+import javax.xml.namespace.QName;
+
+import org.apache.axis.engine.AxisFault;
+import org.apache.axis.engine.Provider;
+import org.apache.wsdl.WSDLService;
+import org.apache.wsdl.impl.WSDLServiceImpl;
+
+
+public class AxisService extends WSDLServiceImpl implements WSDLService,ParameterInclude,FlowInclude,PhasesInclude , DescriptionConstants{
+
+    protected HashMap operationsMap = new HashMap();
+
+    public AxisService(){
+        this.setComponentProperty(MODULEREF_KEY,new ArrayList());
+        this.setComponentProperty(PARAMETER_KEY, new ParameterIncludeImpl());
+        this.setComponentProperty(PHASES_KEY, new PhasesIncludeImpl());
+    }
+    
+    public AxisService(QName qName){
+        this();
+        this.setName(qName);        
+    }
+    
+    /* (non-Javadoc)
+     * @see org.apache.axis.description.AxisService#addModule(javax.xml.namespace.QName)
+     */
+    public void addModule(QName moduleref) {
+        if( null == moduleref)return;
+       Collection collectionModule = (Collection) this.getComponentProperty(MODULEREF_KEY);
+       collectionModule.add(moduleref);
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.axis.description.AxisService#getModules()
+     */
+    public Collection getModules() {
+        return (Collection)this.getComponentProperty(MODULEREF_KEY);
+    }
+
+    public AxisOperation getOperation(QName operationName) {
+        //todo The key has been changed from the qname to the local name because
+        //todo when comparing the namespace will not be available
+        return (AxisOperation)this.operationsMap.get(operationName.getLocalPart());
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.axis.description.AxisService#addOperation(org.apache.axis.description.AxisOperation)
+     */
+    public void addOperation(AxisOperation operation) {
+        //todo The key has been changed from the qname to the local name because
+        //todo when comparing the namespace will not be available
+        if(null != operation){
+            this.operationsMap.put(operation.getName().getLocalPart(),operation);
+        }
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.axis.description.AxisService#setClassLoader(java.lang.ClassLoader)
+     */
+    public void setClassLoader(ClassLoader classLoader) {
+        if(null != classLoader){
+            this.setComponentProperty(CLASSLOADER_KEY, classLoader);
+        }
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.axis.description.AxisService#getClassLoader()
+     */
+    public ClassLoader getClassLoader() {
+        return (ClassLoader)this.getComponentProperty(CLASSLOADER_KEY);
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.axis.description.AxisService#setContextPath(java.lang.String)
+     */
+    public void setContextPath(String contextPath) {
+        if(null != contextPath){
+            this.setComponentProperty(CONTEXTPATH_KEY, contextPath);
+        }
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.axis.description.AxisService#getContextPath()
+     */
+    public String getContextPath() {
+        return (String)this.getComponentProperty(CONTEXTPATH_KEY);
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.axis.description.AxisService#setProvider(org.apache.axis.engine.Provider)
+     */
+    public void setProvider(Provider provider) {
+        if(null != provider){
+            this.setComponentProperty(PROVIDER_KEY, provider);
+        }
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.axis.description.AxisService#getProvider()
+     */
+    public Provider getProvider() {
+        return (Provider)this.getComponentProperty(PROVIDER_KEY);
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.axis.description.AxisService#setStyle(javax.swing.text.Style)
+     */
+    public void setStyle(Style style) {
+        if(null != style){
+            this.setComponentProperty(STYLE_KEY, style);
+        }
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.axis.description.AxisService#getStyle()
+     */
+    public Style getStyle() {
+        return (Style)this.getComponentProperty(STYLE_KEY);
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.axis.description.PhasesInclude#getPhases(java.util.ArrayList, int)
+     */
+    public void setPhases(ArrayList phases, int flow) throws AxisFault{
+        if(phases == null) return;
+        PhasesIncludeImpl phaseInclude =
+            (PhasesIncludeImpl)this.getComponentProperty(PHASES_KEY);
+        phaseInclude.setPhases(phases, flow);
+    }
+    
+    /* (non-Javadoc)
+     * @see org.apache.axis.description.PhasesInclude#getPhases(int)
+     */
+    public ArrayList getPhases(int flow) throws AxisFault{
+        PhasesIncludeImpl phaseInclude =
+            (PhasesIncludeImpl)this.getComponentProperty(PHASES_KEY);
+        return(ArrayList)phaseInclude.getPhases(flow);
+    }
+    
+    /* (non-Javadoc)
+     * @see org.apache.axis.description.ParameterInclude#addParameter(org.apache.axis.description.Parameter)
+     */
+    public void addParameter(Parameter param) {
+        if(null == param) return;
+        ParameterIncludeImpl paramInclude =
+             (ParameterIncludeImpl)this.getComponentProperty(PARAMETER_KEY);
+        paramInclude.addParameter(param);
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.axis.description.ParameterInclude#getParameter(java.lang.String)
+     */
+    public Parameter getParameter(String name) {
+        ParameterIncludeImpl paramInclude = (ParameterIncludeImpl)this.getComponentProperty(PARAMETER_KEY);
+        return (Parameter)paramInclude.getParameter(name);
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.axis.description.FlowInclude#getInFlow()
+     */
+    public Flow getInFlow() {
+        return (Flow)this.getComponentProperty(INFLOW_KEY);
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.axis.description.FlowInclude#setInFlow(org.apache.axis.description.Flow)
+     */
+    public void setInFlow(Flow inFlow) {
+        if(null != inFlow){
+            this.setComponentProperty(INFLOW_KEY, inFlow);
+        }
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.axis.description.FlowInclude#getOutFlow()
+     */
+    public Flow getOutFlow() {
+        return (Flow)this.getComponentProperty(OUTFLOW_KEY);
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.axis.description.FlowInclude#setOutFlow(org.apache.axis.description.Flow)
+     */
+    public void setOutFlow(Flow outFlow){
+        if(null != outFlow){
+            this.setComponentProperty(OUTFLOW_KEY, outFlow);
+        }
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.axis.description.FlowInclude#getFaultFlow()
+     */
+    public Flow getFaultFlow() {
+        return (Flow)this.getComponentProperty(FAULTFLOW_KEY);
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.axis.description.FlowInclude#setFaultFlow(org.apache.axis.description.Flow)
+     */
+    public void setFaultFlow(Flow faultFlow) {
+        if(null != faultFlow){
+            this.setComponentProperty(FAULTFLOW_KEY, faultFlow);
+        }
+    }
+    
+    public void setServiceClass(Class serviceclass) {
+        if(serviceclass != null)
+            this.setComponentProperty(DescriptionConstants.SERVICE_CLASS, serviceclass);
+    }
+
+    public Class getServiceClass() {
+        return (Class)this.getComponentProperty(DescriptionConstants.SERVICE_CLASS);
+    }
+
+    
+
+}

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/AxisTransport.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/AxisTransport.java?view=diff&r1=153170&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/AxisTransport.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/AxisTransport.java Wed Feb  9 22:32:42 2005
@@ -16,9 +16,6 @@
 package org.apache.axis.description;
 
 import org.apache.axis.engine.AxisFault;
-import org.apache.axis.impl.description.FlowIncludeImpl;
-import org.apache.axis.impl.description.ParameterIncludeImpl;
-import org.apache.axis.impl.description.PhasesIncludeImpl;
 
 import javax.xml.namespace.QName;
 import java.util.ArrayList;

Added: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/FlowImpl.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/FlowImpl.java?view=auto&rev=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/FlowImpl.java (added)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/FlowImpl.java Wed Feb  9 22:32:42 2005
@@ -0,0 +1,38 @@
+/*
+ * Copyright 2001-2004 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.axis.description;
+
+
+import java.util.Vector;
+import java.util.List;
+import java.util.ArrayList;
+
+public class FlowImpl implements Flow {
+   protected List list;
+   public FlowImpl(){
+        list = new ArrayList();
+   }
+   public void addHandler(HandlerMetaData handler) {
+       list.add(handler);
+   }
+   public HandlerMetaData getHandler(int index) {
+       return (HandlerMetaData)list.get(index);
+   }
+   public int getHandlerCount() {
+       return list.size();
+   }
+}

Added: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/FlowIncludeImpl.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/FlowIncludeImpl.java?view=auto&rev=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/FlowIncludeImpl.java (added)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/FlowIncludeImpl.java Wed Feb  9 22:32:42 2005
@@ -0,0 +1,47 @@
+/*
+ * Copyright 2003,2004 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.axis.description;
+
+
+public class FlowIncludeImpl implements FlowInclude{
+    private Flow in;
+    private Flow out;
+    private Flow fault;
+    public Flow getFaultFlow() {
+        return fault;
+    }
+
+    public Flow getInFlow() {
+        return in;
+    }
+
+    public Flow getOutFlow() {
+        return out;
+    }
+
+    public void setFaultFlow(Flow flow) {
+        this.fault = flow;
+    }
+
+    public void setInFlow(Flow flow) {
+        this.in = flow;
+    }
+
+    public void setOutFlow(Flow flow) {
+        this.out = flow;
+    }
+
+}

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/HandlerMetaData.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/HandlerMetaData.java?view=diff&r1=153170&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/HandlerMetaData.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/HandlerMetaData.java Wed Feb  9 22:32:42 2005
@@ -16,7 +16,6 @@
 package org.apache.axis.description;
 
 import org.apache.axis.engine.Handler;
-import org.apache.axis.impl.description.ParameterIncludeImpl;
 
 import javax.xml.namespace.QName;
 

Added: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/ParameterImpl.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/ParameterImpl.java?view=auto&rev=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/ParameterImpl.java (added)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/ParameterImpl.java Wed Feb  9 22:32:42 2005
@@ -0,0 +1,61 @@
+/*
+* Copyright 2003,2004 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.axis.description;
+
+
+public class ParameterImpl implements Parameter  {
+    private String name;
+    private String value;
+    private boolean locked;
+    private int type = TEXT_PARAMETER;
+
+    public ParameterImpl() {
+    }
+
+    public ParameterImpl(String name, String value) {
+        this.name = name;
+        this.value = value;
+    }
+
+    public void setName(String name) {
+        this.name = name;
+    }
+
+    public void setValue(String value) {
+        this.value = value;
+    }
+
+    public boolean isLocked() {
+        return locked;
+    }
+
+    public void setLocked(boolean value) {
+        locked = value;
+    }
+
+
+    public String getName() {
+        return name;
+    }
+
+    public Object getValue() {
+        return value;
+    }
+    public int getParameterType() {
+        return type;
+    }
+
+}

Added: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/ParameterIncludeImpl.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/ParameterIncludeImpl.java?view=auto&rev=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/ParameterIncludeImpl.java (added)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/ParameterIncludeImpl.java Wed Feb  9 22:32:42 2005
@@ -0,0 +1,35 @@
+/*
+ * Copyright 2003,2004 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.axis.description;
+
+
+import java.util.HashMap;
+
+public class ParameterIncludeImpl implements ParameterInclude {
+    protected HashMap parmeters;
+    public ParameterIncludeImpl(){
+        parmeters = new HashMap();
+    }
+    public void addParameter(Parameter param) {
+        if(param != null){
+            parmeters.put(param.getName(),param);
+        }
+    }
+
+    public Parameter getParameter(String name) {
+        return (Parameter)parmeters.get(name);
+    }
+}

Added: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/PhasesIncludeImpl.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/PhasesIncludeImpl.java?view=auto&rev=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/PhasesIncludeImpl.java (added)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/PhasesIncludeImpl.java Wed Feb  9 22:32:42 2005
@@ -0,0 +1,55 @@
+/*
+ * Copyright 2003,2004 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.axis.description;
+
+import org.apache.axis.engine.AxisFault;
+import org.apache.axis.engine.EngineRegistry;
+
+import java.util.ArrayList;
+
+/**
+ * Util class to implements the Phases include with delegation 
+ */
+public class PhasesIncludeImpl implements PhasesInclude{
+    private ArrayList inflow;
+    private ArrayList outflow;
+    private ArrayList faultflow;
+    
+    public ArrayList getPhases(int flow) throws AxisFault {
+        if(flow == EngineRegistry.INFLOW){
+            return inflow;
+        }else if(flow == EngineRegistry.OUTFLOW){
+            return outflow;
+        }else if(flow == EngineRegistry.FAULTFLOW){
+            return faultflow;
+        }else{
+            throw new AxisFault("Unknown type flow ");
+        }
+
+    }
+
+    public void setPhases(ArrayList phases, int flow) throws AxisFault {
+        if(flow == EngineRegistry.INFLOW){
+            inflow = phases;
+        }else if(flow == EngineRegistry.OUTFLOW){
+            outflow= phases;
+        }else if(flow == EngineRegistry.FAULTFLOW){
+            faultflow = phases;
+        }else{
+            throw new AxisFault("Unknown type flow ");
+        }
+    }
+}

Added: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/SimpleAxisOperationImpl.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/SimpleAxisOperationImpl.java?view=auto&rev=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/SimpleAxisOperationImpl.java (added)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/description/SimpleAxisOperationImpl.java Wed Feb  9 22:32:42 2005
@@ -0,0 +1,238 @@
+/*
+ * Copyright 2003,2004 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.axis.description;
+
+import org.apache.wsdl.MessageReference;
+import org.apache.wsdl.WSDLFeature;
+import org.apache.wsdl.WSDLOperation;
+import org.apache.wsdl.WSDLProperty;
+import org.apache.wsdl.impl.WSDLOperationImpl;
+
+import javax.xml.namespace.QName;
+import java.util.HashMap;
+import java.util.List;
+
+public class SimpleAxisOperationImpl implements AxisOperation {
+    protected WSDLOperation wsdlOperation;
+    protected ParameterInclude parameters;
+    
+    /**
+     * 
+     */
+    public SimpleAxisOperationImpl() {
+        wsdlOperation = new WSDLOperationImpl();
+        parameters = new ParameterIncludeImpl();
+    }
+
+     public SimpleAxisOperationImpl(QName name) {
+        wsdlOperation = new WSDLOperationImpl();
+        wsdlOperation.setName(name);
+        parameters = new ParameterIncludeImpl();
+    }
+
+
+    /**
+     * @param param
+     */
+    public void addParameter(Parameter param) {
+        parameters.addParameter(param);
+    }
+
+    /**
+     * @param name
+     * @return
+     */
+    public Parameter getParameter(String name) {
+        return parameters.getParameter(name);
+    }
+
+    /**
+     * @param feature
+     */
+    public void addFeature(WSDLFeature feature) {
+        wsdlOperation.addFeature(feature);
+    }
+
+    /**
+     * @param wsdlProperty
+     */
+    public void addPorperty(WSDLProperty wsdlProperty) {
+        wsdlOperation.addPorperty(wsdlProperty);
+    }
+
+    /**
+     * @return
+     */
+    public HashMap getComponentProperties() {
+        return wsdlOperation.getComponentProperties();
+    }
+
+    /**
+     * @param key
+     * @return
+     */
+    public Object getComponentProperty(Object key) {
+        return wsdlOperation.getComponentProperty(key);
+    }
+
+    /**
+     * @return
+     */
+    public List getFeatures() {
+        return wsdlOperation.getFeatures();
+    }
+
+    /**
+     * @return
+     */
+    public List getInfaults() {
+        return wsdlOperation.getInfaults();
+    }
+
+    /**
+     * @return
+     */
+    public MessageReference getInputMessage() {
+        return wsdlOperation.getInputMessage();
+    }
+
+    /**
+     * @return
+     */
+    public String getMessageExchangePattern() {
+        return wsdlOperation.getMessageExchangePattern();
+    }
+
+    /**
+     * @return
+     */
+    public QName getName() {
+        return wsdlOperation.getName();
+    }
+
+    /**
+     * @return
+     */
+    public List getOutfaults() {
+        return wsdlOperation.getOutfaults();
+    }
+
+    /**
+     * @return
+     */
+    public MessageReference getOutputMessage() {
+        return wsdlOperation.getOutputMessage();
+    }
+
+    /**
+     * @return
+     */
+    public List getProperties() {
+        return wsdlOperation.getProperties();
+    }
+
+    /**
+     * @return
+     */
+    public int getStyle() {
+        return wsdlOperation.getStyle();
+    }
+
+    /**
+     * @return
+     */
+    public String getTargetnemespace() {
+        return wsdlOperation.getTargetnemespace();
+    }
+
+    /**
+     * @return
+     */
+    public boolean isSafe() {
+        return wsdlOperation.isSafe();
+    }
+
+    /**
+     * @param properties
+     */
+    public void setComponentProperties(HashMap properties) {
+        wsdlOperation.setComponentProperties(properties);
+    }
+
+    public void setMessageExchangePattern(String messageExchangePattern) {
+        wsdlOperation.setMessageExchangePattern(messageExchangePattern);
+    }
+    /**
+     * @param key
+     * @param obj
+     */
+    public void setComponentProperty(Object key, Object obj) {
+        wsdlOperation.setComponentProperty(key, obj);
+    }
+
+    /**
+     * @param infaults
+     */
+    public void setInfaults(List infaults) {
+        wsdlOperation.setInfaults(infaults);
+    }
+
+    /**
+     * @param inputMessage
+     */
+    public void setInputMessage(MessageReference inputMessage) {
+        wsdlOperation.setInputMessage(inputMessage);
+    }
+
+   
+    /**
+     * @param name
+     */
+    public void setName(QName name) {
+        wsdlOperation.setName(name);
+    }
+
+    /**
+     * @param outfaults
+     */
+    public void setOutfaults(List outfaults) {
+        wsdlOperation.setOutfaults(outfaults);
+    }
+
+    /**
+     * @param outputMessage
+     */
+    public void setOutputMessage(MessageReference outputMessage) {
+        wsdlOperation.setOutputMessage(outputMessage);
+    }
+
+    /**
+     * @param safe
+     */
+    public void setSafety(boolean safe) {
+        wsdlOperation.setSafety(safe);
+    }
+
+    /**
+     * @param style
+     */
+    public void setStyle(int style) {
+        wsdlOperation.setStyle(style);
+    }
+
+    
+
+}

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/AxisEngine.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/AxisEngine.java?view=diff&r1=153170&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/AxisEngine.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/AxisEngine.java Wed Feb  9 22:32:42 2005
@@ -18,8 +18,8 @@
 
 import org.apache.axis.context.MessageContext;
 import org.apache.axis.description.AxisGlobal;
+import org.apache.axis.description.AxisService;
 import org.apache.axis.description.AxisTransport;
-import org.apache.axis.impl.description.AxisService;
 import org.apache.axis.om.OMFactory;
 import org.apache.axis.om.SOAPEnvelope;
 import org.apache.commons.logging.Log;

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/Dispatcher.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/Dispatcher.java?view=diff&r1=153170&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/Dispatcher.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/Dispatcher.java Wed Feb  9 22:32:42 2005
@@ -16,14 +16,14 @@
 
 package org.apache.axis.engine;
 
+import javax.xml.namespace.QName;
+
 import org.apache.axis.addressing.EndpointReference;
 import org.apache.axis.context.MessageContext;
+import org.apache.axis.description.AxisService;
 import org.apache.axis.description.HandlerMetaData;
-import org.apache.axis.impl.description.AxisService;
-import org.apache.axis.impl.handlers.AbstractHandler;
-import org.apache.axis.impl.handlers.OpNameFinder;
-
-import javax.xml.namespace.QName;
+import org.apache.axis.handlers.AbstractHandler;
+import org.apache.axis.handlers.OpNameFinder;
 
 public class Dispatcher extends AbstractHandler implements Handler {
 	public static final QName NAME = new QName("http://axis.ws.apache.org","Disapatcher");

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/EngineRegistry.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/EngineRegistry.java?view=diff&r1=153170&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/EngineRegistry.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/EngineRegistry.java Wed Feb  9 22:32:42 2005
@@ -17,14 +17,15 @@
 package org.apache.axis.engine;
 
 
+import java.util.ArrayList;
+import java.util.HashMap;
+
+import javax.xml.namespace.QName;
+
 import org.apache.axis.description.AxisGlobal;
 import org.apache.axis.description.AxisModule;
+import org.apache.axis.description.AxisService;
 import org.apache.axis.description.AxisTransport;
-import org.apache.axis.impl.description.AxisService;
-
-import javax.xml.namespace.QName;
-import java.util.ArrayList;
-import java.util.HashMap;
 
 /**
  *  The palce where all the Globel states of Axis is kept. 

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/EngineRegistryFactory.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/EngineRegistryFactory.java?view=diff&r1=153170&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/EngineRegistryFactory.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/EngineRegistryFactory.java Wed Feb  9 22:32:42 2005
@@ -15,11 +15,11 @@
  */
 package org.apache.axis.engine;
 
+import javax.xml.stream.XMLStreamException;
+
 import org.apache.axis.deployment.DeploymentEngine;
 import org.apache.axis.deployment.DeploymentException;
 import org.apache.axis.phaseresolver.PhaseException;
-
-import javax.xml.stream.XMLStreamException;
 
 
 public class EngineRegistryFactory {

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/Handler.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/Handler.java?view=diff&r1=153170&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/Handler.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/Handler.java Wed Feb  9 22:32:42 2005
@@ -16,12 +16,13 @@
 
 package org.apache.axis.engine;
 
+import java.io.Serializable;
+
+import javax.xml.namespace.QName;
+
 import org.apache.axis.context.MessageContext;
 import org.apache.axis.description.HandlerMetaData;
 import org.apache.axis.description.Parameter;
-
-import javax.xml.namespace.QName;
-import java.io.Serializable;
 
 public interface Handler extends Serializable{
     public void init(HandlerMetaData handlerdesc);

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/Phase.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/Phase.java?view=diff&r1=153170&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/Phase.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/Phase.java Wed Feb  9 22:32:42 2005
@@ -22,7 +22,7 @@
 
 import org.apache.axis.context.MessageContext;
 import org.apache.axis.description.HandlerMetaData;
-import org.apache.axis.impl.handlers.AbstractHandler;
+import org.apache.axis.handlers.AbstractHandler;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/Provider.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/Provider.java?view=diff&r1=153170&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/Provider.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/Provider.java Wed Feb  9 22:32:42 2005
@@ -14,9 +14,9 @@
  * limitations under the License.
  */
 package org.apache.axis.engine;
-import org.apache.axis.context.MessageContext;
-
 import java.io.Serializable;
+
+import org.apache.axis.context.MessageContext;
 
 
 /**

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/ReceiverLocator.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/ReceiverLocator.java?view=diff&r1=153170&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/ReceiverLocator.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/ReceiverLocator.java Wed Feb  9 22:32:42 2005
@@ -17,7 +17,7 @@
 package org.apache.axis.engine;
 
 import org.apache.axis.context.MessageContext;
-import org.apache.axis.impl.receivers.InOutSyncReceiver;
+import org.apache.axis.receivers.InOutSyncReceiver;
 
 public class ReceiverLocator {
     public static Receiver locateReceiver(MessageContext msgCtx) throws AxisFault {

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/TransportSenderLocator.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/TransportSenderLocator.java?view=diff&r1=153170&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/TransportSenderLocator.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/engine/TransportSenderLocator.java Wed Feb  9 22:32:42 2005
@@ -16,11 +16,11 @@
 
 package org.apache.axis.engine;
 
-import org.apache.axis.context.MessageContext;
-import org.apache.axis.impl.transport.http.HTTPTransportSender;
-import org.apache.axis.impl.transport.tcp.TCPTrasnportSender;
-
 import java.io.OutputStream;
+
+import org.apache.axis.context.MessageContext;
+import org.apache.axis.transport.http.HTTPTransportSender;
+import org.apache.axis.transport.tcp.TCPTrasnportSender;
 
 
 public class TransportSenderLocator {

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/handlers/AbstractHandler.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/handlers/AbstractHandler.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/handlers/AbstractHandler.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/handlers/AbstractHandler.java Wed Feb  9 22:32:42 2005
@@ -13,14 +13,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.axis.impl.handlers;
+package org.apache.axis.handlers;
+
+import javax.xml.namespace.QName;
 
 import org.apache.axis.context.MessageContext;
 import org.apache.axis.description.HandlerMetaData;
 import org.apache.axis.description.Parameter;
 import org.apache.axis.engine.AxisFault;
 import org.apache.axis.engine.Handler;
-import javax.xml.namespace.QName;
 
 public abstract class AbstractHandler implements Handler {
     private static HandlerMetaData EMPTY_HANDLER_METADATA = new HandlerMetaData();

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/handlers/OpNameFinder.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/handlers/OpNameFinder.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/handlers/OpNameFinder.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/handlers/OpNameFinder.java Wed Feb  9 22:32:42 2005
@@ -13,16 +13,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.axis.impl.handlers;
+package org.apache.axis.handlers;
 
 import javax.xml.namespace.QName;
 
 import org.apache.axis.context.MessageContext;
 import org.apache.axis.description.AxisOperation;
+import org.apache.axis.description.AxisService;
 import org.apache.axis.description.HandlerMetaData;
 import org.apache.axis.engine.AxisFault;
 import org.apache.axis.engine.Constants;
-import org.apache.axis.impl.description.AxisService;
 import org.apache.axis.om.OMElement;
 import org.apache.axis.om.OMNamespace;
 import org.apache.axis.om.OMNode;

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMAttributeImpl.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMAttributeImpl.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMAttributeImpl.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMAttributeImpl.java Wed Feb  9 22:32:42 2005
@@ -1,4 +1,4 @@
-package org.apache.axis.impl.llom;
+package org.apache.axis.om.impl.llom;
 
 import java.util.regex.Matcher;
 import java.util.regex.Pattern;

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMDocument.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMDocument.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMDocument.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMDocument.java Wed Feb  9 22:32:42 2005
@@ -1,4 +1,4 @@
-package org.apache.axis.impl.llom;
+package org.apache.axis.om.impl.llom;
 
 import org.apache.axis.om.OMElement;
 import org.apache.axis.om.OMXMLParserWrapper;

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMElementImpl.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMElementImpl.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMElementImpl.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMElementImpl.java Wed Feb  9 22:32:42 2005
@@ -1,4 +1,4 @@
-package org.apache.axis.impl.llom;
+package org.apache.axis.om.impl.llom;
 
 import java.util.HashMap;
 import java.util.Iterator;
@@ -8,10 +8,6 @@
 import javax.xml.stream.XMLStreamReader;
 import javax.xml.stream.XMLStreamWriter;
 
-import org.apache.axis.impl.llom.serialize.StreamingOMSerializer;
-import org.apache.axis.impl.llom.traverse.OMChildrenIterator;
-import org.apache.axis.impl.llom.traverse.OMChildrenQNameIterator;
-import org.apache.axis.impl.llom.util.StreamWriterToContentHandlerConverter;
 import org.apache.axis.om.OMAttribute;
 import org.apache.axis.om.OMConstants;
 import org.apache.axis.om.OMElement;
@@ -21,6 +17,10 @@
 import org.apache.axis.om.OMNode;
 import org.apache.axis.om.OMText;
 import org.apache.axis.om.OMXMLParserWrapper;
+import org.apache.axis.om.impl.llom.serialize.StreamingOMSerializer;
+import org.apache.axis.om.impl.llom.traverse.OMChildrenIterator;
+import org.apache.axis.om.impl.llom.traverse.OMChildrenQNameIterator;
+import org.apache.axis.om.impl.llom.util.StreamWriterToContentHandlerConverter;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMNamedNodeImpl.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMNamedNodeImpl.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMNamedNodeImpl.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMNamedNodeImpl.java Wed Feb  9 22:32:42 2005
@@ -1,4 +1,4 @@
-package org.apache.axis.impl.llom;
+package org.apache.axis.om.impl.llom;
 
 import javax.xml.namespace.QName;
 

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMNamespaceImpl.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMNamespaceImpl.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMNamespaceImpl.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMNamespaceImpl.java Wed Feb  9 22:32:42 2005
@@ -1,4 +1,4 @@
-package org.apache.axis.impl.llom;
+package org.apache.axis.om.impl.llom;
 
 import org.apache.axis.om.OMNamespace;
 

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMNavigator.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMNavigator.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMNavigator.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMNavigator.java Wed Feb  9 22:32:42 2005
@@ -20,7 +20,7 @@
 *
 
 */
-package org.apache.axis.impl.llom;
+package org.apache.axis.om.impl.llom;
 
 import org.apache.axis.om.OMElement;
 import org.apache.axis.om.OMNode;

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMNodeImpl.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMNodeImpl.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMNodeImpl.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMNodeImpl.java Wed Feb  9 22:32:42 2005
@@ -1,4 +1,4 @@
-package org.apache.axis.impl.llom;
+package org.apache.axis.om.impl.llom;
 
 import javax.xml.stream.XMLStreamException;
 import javax.xml.stream.XMLStreamWriter;

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMStAXWrapper.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMStAXWrapper.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMStAXWrapper.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMStAXWrapper.java Wed Feb  9 22:32:42 2005
@@ -1,4 +1,4 @@
-package org.apache.axis.impl.llom;
+package org.apache.axis.om.impl.llom;
 
 import java.util.Iterator;
 import java.util.Stack;
@@ -10,7 +10,6 @@
 import javax.xml.stream.XMLStreamException;
 import javax.xml.stream.XMLStreamReader;
 
-import org.apache.axis.impl.llom.exception.OMStreamingException;
 import org.apache.axis.om.OMAttribute;
 import org.apache.axis.om.OMElement;
 import org.apache.axis.om.OMNamedNode;
@@ -18,6 +17,7 @@
 import org.apache.axis.om.OMNode;
 import org.apache.axis.om.OMText;
 import org.apache.axis.om.OMXMLParserWrapper;
+import org.apache.axis.om.impl.llom.exception.OMStreamingException;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMTextImpl.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMTextImpl.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMTextImpl.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/OMTextImpl.java Wed Feb  9 22:32:42 2005
@@ -1,4 +1,4 @@
-package org.apache.axis.impl.llom;
+package org.apache.axis.om.impl.llom;
 
 import javax.xml.stream.XMLStreamException;
 import javax.xml.stream.XMLStreamWriter;

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPBodyImpl.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPBodyImpl.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPBodyImpl.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPBodyImpl.java Wed Feb  9 22:32:42 2005
@@ -1,4 +1,4 @@
-package org.apache.axis.impl.llom;
+package org.apache.axis.om.impl.llom;
 
 import java.util.Iterator;
 
@@ -10,6 +10,8 @@
 import org.apache.axis.om.SOAPBody;
 import org.apache.axis.om.SOAPEnvelope;
 import org.apache.axis.om.SOAPFault;
+
+
 
 /**
  * Copyright 2001-2004 The Apache Software Foundation.

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPEnvelopeImpl.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPEnvelopeImpl.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPEnvelopeImpl.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPEnvelopeImpl.java Wed Feb  9 22:32:42 2005
@@ -1,4 +1,4 @@
-package org.apache.axis.impl.llom;
+package org.apache.axis.om.impl.llom;
 
 import org.apache.axis.om.OMConstants;
 import org.apache.axis.om.OMElement;

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPFaultImpl.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPFaultImpl.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPFaultImpl.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPFaultImpl.java Wed Feb  9 22:32:42 2005
@@ -1,4 +1,4 @@
-package org.apache.axis.impl.llom;
+package org.apache.axis.om.impl.llom;
 
 import java.io.PrintWriter;
 import java.io.StringWriter;

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPHeaderBlockImpl.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPHeaderBlockImpl.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPHeaderBlockImpl.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPHeaderBlockImpl.java Wed Feb  9 22:32:42 2005
@@ -1,4 +1,4 @@
-package org.apache.axis.impl.llom;
+package org.apache.axis.om.impl.llom;
 
 import javax.xml.namespace.QName;
 

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPHeaderImpl.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPHeaderImpl.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPHeaderImpl.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/SOAPHeaderImpl.java Wed Feb  9 22:32:42 2005
@@ -1,10 +1,9 @@
-package org.apache.axis.impl.llom;
+package org.apache.axis.om.impl.llom;
 
 import java.util.Iterator;
 
 import javax.xml.namespace.QName;
 
-import org.apache.axis.impl.llom.traverse.OMChildrenWithSpecificAttributeIterator;
 import org.apache.axis.om.OMConstants;
 import org.apache.axis.om.OMException;
 import org.apache.axis.om.OMNamespace;
@@ -12,6 +11,7 @@
 import org.apache.axis.om.SOAPEnvelope;
 import org.apache.axis.om.SOAPHeader;
 import org.apache.axis.om.SOAPHeaderBlock;
+import org.apache.axis.om.impl.llom.traverse.OMChildrenWithSpecificAttributeIterator;
 
 /**
  * Copyright 2001-2004 The Apache Software Foundation.

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/builder/ObjectToOMBuilder.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/builder/ObjectToOMBuilder.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/builder/ObjectToOMBuilder.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/builder/ObjectToOMBuilder.java Wed Feb  9 22:32:42 2005
@@ -1,6 +1,5 @@
-package org.apache.axis.impl.llom.builder;
+package org.apache.axis.om.impl.llom.builder;
 
-import java.util.Vector;
 import java.util.ArrayList;
 import java.util.List;
 

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/builder/StAXBuilder.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/builder/StAXBuilder.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/builder/StAXBuilder.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/builder/StAXBuilder.java Wed Feb  9 22:32:42 2005
@@ -1,10 +1,8 @@
-package org.apache.axis.impl.llom.builder;
+package org.apache.axis.om.impl.llom.builder;
 
 import javax.xml.stream.XMLStreamConstants;
 import javax.xml.stream.XMLStreamReader;
 
-import org.apache.axis.impl.llom.OMElementImpl;
-import org.apache.axis.impl.llom.OMNodeImpl;
 import org.apache.axis.om.OMConstants;
 import org.apache.axis.om.OMElement;
 import org.apache.axis.om.OMException;
@@ -12,6 +10,8 @@
 import org.apache.axis.om.OMNamespace;
 import org.apache.axis.om.OMNode;
 import org.apache.axis.om.OMXMLParserWrapper;
+import org.apache.axis.om.impl.llom.OMElementImpl;
+import org.apache.axis.om.impl.llom.OMNodeImpl;
 
 /**
  * Copyright 2001-2004 The Apache Software Foundation.

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/builder/StAXOMBuilder.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/builder/StAXOMBuilder.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/builder/StAXOMBuilder.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/builder/StAXOMBuilder.java Wed Feb  9 22:32:42 2005
@@ -1,9 +1,8 @@
-package org.apache.axis.impl.llom.builder;
+package org.apache.axis.om.impl.llom.builder;
 
 import javax.xml.stream.XMLStreamConstants;
 import javax.xml.stream.XMLStreamReader;
 
-import org.apache.axis.impl.llom.OMDocument;
 import org.apache.axis.om.OMElement;
 import org.apache.axis.om.OMException;
 import org.apache.axis.om.OMFactory;
@@ -11,6 +10,7 @@
 import org.apache.axis.om.OMNode;
 import org.apache.axis.om.OMXMLParserWrapper;
 import org.apache.axis.om.SOAPEnvelope;
+import org.apache.axis.om.impl.llom.OMDocument;
 
 /**
  * Copyright 2001-2004 The Apache Software Foundation.

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/builder/StAXSOAPModelBuilder.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/builder/StAXSOAPModelBuilder.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/builder/StAXSOAPModelBuilder.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/builder/StAXSOAPModelBuilder.java Wed Feb  9 22:32:42 2005
@@ -1,11 +1,8 @@
-package org.apache.axis.impl.llom.builder;
+package org.apache.axis.om.impl.llom.builder;
 
 import javax.xml.stream.XMLStreamConstants;
 import javax.xml.stream.XMLStreamReader;
 
-import org.apache.axis.impl.llom.OMElementImpl;
-import org.apache.axis.impl.llom.SOAPEnvelopeImpl;
-import org.apache.axis.impl.llom.exception.OMBuilderException;
 import org.apache.axis.om.OMConstants;
 import org.apache.axis.om.OMElement;
 import org.apache.axis.om.OMException;
@@ -14,6 +11,9 @@
 import org.apache.axis.om.OMNode;
 import org.apache.axis.om.SOAPBody;
 import org.apache.axis.om.SOAPEnvelope;
+import org.apache.axis.om.impl.llom.OMElementImpl;
+import org.apache.axis.om.impl.llom.SOAPEnvelopeImpl;
+import org.apache.axis.om.impl.llom.exception.OMBuilderException;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/exception/OMBuilderException.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/exception/OMBuilderException.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/exception/OMBuilderException.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/exception/OMBuilderException.java Wed Feb  9 22:32:42 2005
@@ -1,4 +1,4 @@
-package org.apache.axis.impl.llom.exception;
+package org.apache.axis.om.impl.llom.exception;
 
 import org.apache.axis.om.OMException;
 

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/exception/OMSerializerException.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/exception/OMSerializerException.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/exception/OMSerializerException.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/exception/OMSerializerException.java Wed Feb  9 22:32:42 2005
@@ -1,4 +1,4 @@
-package org.apache.axis.impl.llom.exception;
+package org.apache.axis.om.impl.llom.exception;
 
 /**
  * Copyright 2001-2004 The Apache Software Foundation.

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/exception/OMStreamingException.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/exception/OMStreamingException.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/exception/OMStreamingException.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/exception/OMStreamingException.java Wed Feb  9 22:32:42 2005
@@ -1,4 +1,4 @@
-package org.apache.axis.impl.llom.exception;
+package org.apache.axis.om.impl.llom.exception;
 
 import org.apache.axis.om.OMException;
 

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/factory/OMLinkedListImplFactory.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/factory/OMLinkedListImplFactory.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/factory/OMLinkedListImplFactory.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/factory/OMLinkedListImplFactory.java Wed Feb  9 22:32:42 2005
@@ -1,20 +1,11 @@
-package org.apache.axis.impl.llom.factory;
+package org.apache.axis.om.impl.llom.factory;
 
 import java.util.Stack;
 
-import org.apache.axis.impl.llom.OMElementImpl;
-import org.apache.axis.impl.llom.OMNamespaceImpl;
-import org.apache.axis.impl.llom.OMTextImpl;
-import org.apache.axis.impl.llom.SOAPBodyImpl;
-import org.apache.axis.impl.llom.SOAPEnvelopeImpl;
-import org.apache.axis.impl.llom.SOAPFaultImpl;
-import org.apache.axis.impl.llom.SOAPHeaderBlockImpl;
-import org.apache.axis.impl.llom.SOAPHeaderImpl;
 import org.apache.axis.om.OMConstants;
 import org.apache.axis.om.OMElement;
 import org.apache.axis.om.OMFactory;
 import org.apache.axis.om.OMNamespace;
-import org.apache.axis.om.OMNode;
 import org.apache.axis.om.OMText;
 import org.apache.axis.om.OMXMLParserWrapper;
 import org.apache.axis.om.SOAPBody;
@@ -22,6 +13,15 @@
 import org.apache.axis.om.SOAPFault;
 import org.apache.axis.om.SOAPHeader;
 import org.apache.axis.om.SOAPHeaderBlock;
+import org.apache.axis.om.impl.llom.OMElementImpl;
+import org.apache.axis.om.impl.llom.OMNamespaceImpl;
+import org.apache.axis.om.impl.llom.OMTextImpl;
+import org.apache.axis.om.impl.llom.SOAPBodyImpl;
+import org.apache.axis.om.impl.llom.SOAPEnvelopeImpl;
+import org.apache.axis.om.impl.llom.SOAPFaultImpl;
+import org.apache.axis.om.impl.llom.SOAPHeaderBlockImpl;
+import org.apache.axis.om.impl.llom.SOAPHeaderImpl;
+
 
 /**
  * Copyright 2001-2004 The Apache Software Foundation.

Modified: webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/factory/OMXMLBuilderFactory.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/factory/OMXMLBuilderFactory.java?view=diff&r1=153162&r2=153171
==============================================================================
--- webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/factory/OMXMLBuilderFactory.java (original)
+++ webservices/axis/trunk/java/dev/scratch/prototype2/src/java/org/apache/axis/om/impl/llom/factory/OMXMLBuilderFactory.java Wed Feb  9 22:32:42 2005
@@ -1,10 +1,10 @@
-package org.apache.axis.impl.llom.factory;
-
-import org.apache.axis.impl.llom.builder.StAXOMBuilder;
-import org.apache.axis.impl.llom.builder.StAXSOAPModelBuilder;
-import org.apache.axis.om.OMFactory;
+package org.apache.axis.om.impl.llom.factory;
 
 import javax.xml.stream.XMLStreamReader;
+
+import org.apache.axis.om.OMFactory;
+import org.apache.axis.om.impl.llom.builder.StAXOMBuilder;
+import org.apache.axis.om.impl.llom.builder.StAXSOAPModelBuilder;
 
 /**
  * Copyright 2001-2004 The Apache Software Foundation.