You are viewing a plain text version of this content. The canonical link for it is here.
Posted to axis-cvs@ws.apache.org by di...@apache.org on 2005/12/16 18:18:08 UTC

svn commit: r357187 [1/25] - in /webservices/axis2/trunk/java/modules/core/src/org/apache/axis2: ./ addressing/ client/ client/async/ context/ deployment/ deployment/listener/ deployment/repository/util/ deployment/scheduler/ deployment/util/ descripti...

Author: dims
Date: Fri Dec 16 09:13:57 2005
New Revision: 357187

URL: http://svn.apache.org/viewcvs?rev=357187&view=rev
Log:
Indenting and formatting changes ONLY

Modified:
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/AxisFault.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/Constants.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/AddressingConstants.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/AnyContentType.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/EndpointReference.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/MessageInformationHeaders.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/RelatesTo.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/ServiceName.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/Call.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/InOnlyMEPClient.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/InOutMEPClient.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/ListenerManager.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/MEPClient.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/MessageSender.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/Options.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/RESTCall.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/Stub.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/WSDLMEPClientBuilder.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/async/AsyncResult.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/async/Callback.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/AbstractContext.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/ConfigurationContext.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/ConfigurationContextFactory.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/MessageContext.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/MessageContextConstants.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/OperationContext.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/OperationContextFactory.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/ServiceContext.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/ServiceGroupContext.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/SessionContext.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/AxisConfigBuilder.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/DeploymentClassLoader.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/DeploymentConstants.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/DeploymentEngine.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/DeploymentErrorMsgs.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/DeploymentException.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/DescriptionBuilder.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/FileSystemBasedAxisConfigurationCreteator.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/ModuleBuilder.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/ServiceBuilder.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/ServiceGroupBuilder.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/listener/RepositoryListener.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/listener/RepositoryListenerImpl.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/repository/util/ArchiveFileData.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/repository/util/ArchiveReader.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/repository/util/WSInfo.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/repository/util/WSInfoList.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/scheduler/DeploymentIterator.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/scheduler/Scheduler.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/scheduler/SchedulerTask.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/util/PhasesInfo.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/util/Utils.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/AxisDescWSDLComponentFactory.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/AxisMessage.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/AxisOperation.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/AxisOperationFactory.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/AxisService.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/AxisServiceGroup.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/DefinedParameters.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/DescriptionConstants.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/Flow.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/FlowImpl.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/FlowInclude.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/FlowIncludeImpl.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/HandlerDescription.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/InOnlyAxisOperation.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/InOutAxisOperation.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/ModuleConfiguration.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/ModuleDescription.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/OutInAxisOperation.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/OutOnlyAxisOperation.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/Parameter.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/ParameterImpl.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/ParameterInclude.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/ParameterIncludeImpl.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/PhaseRule.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/TransportInDescription.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/TransportOutDescription.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/engine/AbstractDispatcher.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/engine/AddressingBasedDispatcher.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/engine/AxisConfiguration.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/engine/AxisConfigurationCreator.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/engine/AxisEngine.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/engine/AxisError.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/engine/AxisEvent.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/engine/AxisObserver.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/engine/DependencyManager.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/engine/DispatchPhase.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/engine/Handler.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/engine/InstanceDispatcher.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/engine/MessageReceiver.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/engine/Phase.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/engine/RequestURIBasedDispatcher.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/engine/SOAPActionBasedDispatcher.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/engine/SOAPMessageBodyBasedDispatcher.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/fault/AbstractFaultCode.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/fault/FaultCode.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/fault/FaultReason.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/fault/FaultReasonList.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/fault/FaultSubcode.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/fault/SoapFaultSource.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/handlers/AbstractHandler.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/modules/Module.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/phaseresolver/PhaseException.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/phaseresolver/PhaseHolder.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/phaseresolver/PhaseMetadata.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/phaseresolver/PhaseResolver.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/phaseresolver/util/PhaseValidator.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/receivers/AbstractInMessageReceiver.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/receivers/AbstractInOutAsyncMessageReceiver.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/receivers/AbstractInOutSyncMessageReceiver.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/receivers/AbstractMessageReceiver.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/receivers/AbstractRobustInMessageReceiver.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/receivers/RawXMLINOnlyMessageReceiver.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/receivers/RawXMLINOutMessageReceiver.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/receivers/ServerCallback.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/AbstractTransportSender.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/OutTransportInfo.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/TransportListener.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/TransportSender.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/TransportUtils.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/AbstractHTTPSender.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/AxisServlet.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/CommonsHTTPTransportSender.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/HTTPConstants.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/HTTPTransportReceiver.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/HTTPTransportUtils.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/HTTPWorker.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/HttpTransportProperties.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/ListingAgent.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/RESTSender.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/SOAPOverHTTPSender.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/ServletBasedOutTransportInfo.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/SimpleHTTPOutTransportInfo.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/SimpleHTTPServer.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/AdminAppException.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/AuthRequestHandler.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/ErrorResponse.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/HttpRequestHandler.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/HttpRequestHandlerChain.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/HttpService.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/HttpServiceHandler.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/ProxyAuthRequestHandler.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/ProxyRequestHandler.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/RequestLine.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/ResponseWriter.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/SimpleConnList.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/SimpleConnManager.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/SimpleConnSet.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/SimpleConnectionThread.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/SimpleHost.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/SimpleHttpServer.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/SimpleHttpServerConnection.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/SimplePlainSocketFactory.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/SimpleProxy.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/SimpleRequest.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/SimpleResponse.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/SimpleSocketFactory.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/server/TransparentProxyRequestHandler.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/jms/BeanVendorAdapter.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/jms/InvokeException.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/jms/InvokeTimeoutException.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/jms/JMSConnector.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/jms/JMSConnectorFactory.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/jms/JMSConnectorManager.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/jms/JMSConstants.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/jms/JMSEndpoint.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/jms/JMSOutTransportInfo.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/jms/JMSSender.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/jms/JMSURLConnection.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/jms/JMSURLHelper.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/jms/JMSVendorAdapter.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/jms/JMSVendorAdapterFactory.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/jms/JNDIVendorAdapter.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/jms/MapUtils.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/jms/QueueConnector.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/jms/SimpleJMSListener.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/jms/SimpleJMSWorker.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/jms/Subscription.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/jms/TopicConnector.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/local/LocalResponder.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/local/LocalTransportReceiver.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/local/LocalTransportSender.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/mail/EMailSender.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/mail/EmailReceiver.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/mail/MailClient.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/mail/MailTransportSender.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/mail/MailWorker.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/mail/SimpleMailListener.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/mail/server/MailAddress.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/mail/server/MailServer.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/mail/server/MailSorter.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/mail/server/MailSrvConstants.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/mail/server/POP3Server.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/mail/server/POP3Worker.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/mail/server/SMTPServer.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/mail/server/SMTPWorker.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/mail/server/Storage.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/tcp/TCPServer.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/tcp/TCPTransportSender.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/tcp/TCPWorker.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/util/CallbackReceiver.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/util/HostConfiguration.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/util/OptionsParser.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/util/StreamWrapper.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/util/URL.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/util/Utils.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/util/threadpool/ThreadFactory.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/util/threadpool/ThreadPool.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/util/threadpool/ThreadWorker.java

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/AxisFault.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/AxisFault.java?rev=357187&r1=357186&r2=357187&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/AxisFault.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/AxisFault.java Fri Dec 16 09:13:57 2005
@@ -1,18 +1,19 @@
 /*
- * 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.
- */
+* 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;
 
@@ -35,41 +36,51 @@
  * This is a base class for exceptions which are mapped to faults.
  *
  * @see <a href="http://www.w3.org/TR/2003/REC-soap12-part1-20030624/#soapfault">
- * SOAP1.2 specification</a>
+ *      SOAP1.2 specification</a>
  * @see <a href="http://www.w3.org/TR/2000/NOTE-SOAP-20000508/#_Toc478383507">SOAP1.1 Faults</a>
-
- * SOAP faults contain
- * <ol>
- * <li>A fault string
- * <li>A fault code
- * <li>A fault actor
- * <li>Fault details; an xml tree of fault specific elements
- * </ol>
- *
- * As SOAP1.2 faults are a superset of SOAP1.1 faults, this type holds soap1.2 fault information. When
- * a SOAP1.1 fault is created, spurious information can be discarded.
- * Mapping
- * <pre>
- * SOAP1.2              SOAP1.1
- * node                 faultactor
- * reason(0).text       faultstring
- * faultcode.value      faultcode
- * faultcode.subcode    (discarded)
- * detail               detail
- * role                 (discarded)
- * </pre>
+ *      <p/>
+ *      SOAP faults contain
+ *      <ol>
+ *      <li>A fault string
+ *      <li>A fault code
+ *      <li>A fault actor
+ *      <li>Fault details; an xml tree of fault specific elements
+ *      </ol>
+ *      <p/>
+ *      As SOAP1.2 faults are a superset of SOAP1.1 faults, this type holds soap1.2 fault information. When
+ *      a SOAP1.1 fault is created, spurious information can be discarded.
+ *      Mapping
+ *      <pre>
+ *      SOAP1.2              SOAP1.1
+ *      node                 faultactor
+ *      reason(0).text       faultstring
+ *      faultcode.value      faultcode
+ *      faultcode.subcode    (discarded)
+ *      detail               detail
+ *      role                 (discarded)
+ *      </pre>
  */
-
 public class AxisFault extends RemoteException {
 
     /**
      * Contains the faultcode
      */
-    private FaultCode faultCode=new FaultCode();
+    private FaultCode faultCode = new FaultCode();
+
+    /**
+     * our failt reasons
+     */
+    private FaultReasonList reasons = new FaultReasonList();
+
+    /**
+     * assume headers are not used very often
+     */
+    private List headers = new ArrayList(0);
+    private OMElement detail;
 
     /**
      * SOAP1.2: URI of faulting node. Null for unknown.
-     *
+     * <p/>
      * The value of the Node element information item is the URI that
      * identifies the SOAP node that generated the fault.
      * SOAP nodes that do not act as the ultimate SOAP receiver MUST include this element
@@ -80,39 +91,47 @@
     private String nodeURI;
 
     /**
-     * our failt reasons
-     */
-    private FaultReasonList reasons=new FaultReasonList();
-
-    private OMElement detail;
-
-    /**
      * An incoming SOAPFault
      */
     private SOAPFault soapFault;
 
-
     /**
-     * assume headers are not used very often
+     * Make an AxisFault from an incoming SOAPFault
+     *
+     * @param fault that caused the failure
      */
-    private List headers=new ArrayList(0);
+    public AxisFault(SOAPFault fault) {
+        soapFault = fault;
+        init(soapFault);
+    }
 
+    /**
+     * @param message
+     */
+    public AxisFault(String message) {
+        super(message);
+        addReason(message);
+    }
 
     /**
      * construct a fault from an exception
      * TODO: handle AxisFaults or SOAPFaultException implementations differently?
+     *
      * @param cause
      */
     public AxisFault(Throwable cause) {
-        this(cause!=null?cause.getMessage():null,cause);
+        this((cause != null)
+                ? cause.getMessage()
+                : null, cause);
     }
 
     /**
-     * @param message
+     * @param messageText - this will appear as the Text in the Reason information item of SOAP Fault
+     * @param faultCode   - this will appear as the Value in the Code information item of SOAP Fault
      */
-    public AxisFault(String message) {
-        super(message);
-        addReason(message);
+    public AxisFault(String messageText, String faultCode) {
+        this(messageText);
+        setFaultCode(faultCode);
     }
 
     /**
@@ -121,7 +140,8 @@
      */
     public AxisFault(String message, Throwable cause) {
         super(message, cause);
-        if(message!=null) {
+
+        if (message != null) {
             addReason(message);
         }
     }
@@ -129,9 +149,10 @@
     /**
      * @param messageText - this will appear as the Text in the Reason information item of SOAP Fault
      * @param faultCode   - this will appear as the Value in the Code information item of SOAP Fault
+     * @param cause       - this will appear under the Detail information item of SOAP Fault
      */
-    public AxisFault(String messageText, String faultCode) {
-        this(messageText);
+    public AxisFault(String messageText, QName faultCode, Throwable cause) {
+        this(messageText, cause);
         setFaultCode(faultCode);
     }
 
@@ -145,27 +166,65 @@
         setFaultCode(faultCode);
     }
 
+    /**
+     * Add a header to the list of fault headers
+     *
+     * @param header to add.
+     */
+    public void addHeader(SOAPHeader header) {
+        headers.add(header);
+    }
 
     /**
-     * @param messageText - this will appear as the Text in the Reason information item of SOAP Fault
-     * @param faultCode   - this will appear as the Value in the Code information item of SOAP Fault
-     * @param cause       - this will appear under the Detail information item of SOAP Fault
+     * Add a reason for the fault in the empty "" language
+     *
+     * @param text text message
      */
-    public AxisFault(String messageText, QName faultCode, Throwable cause) {
-        this(messageText, cause);
-        setFaultCode(faultCode);
+    public void addReason(String text) {
+        addReason(text, "");
     }
 
+    /**
+     * Add a reason for the fault
+     *
+     * @param text     text message
+     * @param language language
+     */
+    public void addReason(String text, String language) {
+        reasons.add(text, language);
+    }
 
     /**
-     * Make an AxisFault from an incoming SOAPFault
-     * @param fault that caused the failure
+     * Iterate over all of the headers
+     *
+     * @return iterator
      */
-    public AxisFault(SOAPFault fault) {
-        soapFault = fault;
-        init(soapFault);
+    public ListIterator headerIterator() {
+        return headers.listIterator();
     }
 
+    /**
+     * Get at the headers. Useful for java1.5 iteration.
+     *
+     * @return the headers for this fault
+     */
+    public List headers() {
+        return headers;
+    }
+
+    /**
+     * Initialise from a SOAPFault. This is how incoming fault messages
+     * get turned into AxisFaults.
+     *
+     * @param fault incoming fault
+     */
+    private void init(SOAPFault fault) {
+        SOAPFaultCode faultcodesource = fault.getCode();
+
+        faultCode = new FaultCode(faultcodesource);
+        detail = fault.getDetail();
+        fault.getNode();
+    }
 
     /**
      * Make an AxisFault based on a passed Exception.  If the Exception is
@@ -180,87 +239,36 @@
     public static AxisFault makeFault(Exception e) {
         if (e instanceof InvocationTargetException) {
             Throwable t = ((InvocationTargetException) e).getTargetException();
+
             if (t instanceof Exception) {
                 e = (Exception) t;
             }
         }
+
         if (e instanceof AxisFault) {
             return (AxisFault) e;
         }
+
         return new AxisFault(e);
     }
 
-
     /**
-     * Initialise from a SOAPFault. This is how incoming fault messages
-     * get turned into AxisFaults.
-     * @param fault incoming fault
+     * Get the current fault detail
+     *
+     * @return om element
      */
-    private void init(SOAPFault fault) {
-        SOAPFaultCode faultcodesource =fault.getCode();
-        faultCode=new FaultCode(faultcodesource);
-        detail=fault.getDetail();
-        fault.getNode();
+    public OMElement getDetail() {
+        return detail;
     }
 
-
-
     public String getFaultCode() {
         return faultCode.getValueString();
     }
 
-    public void setFaultCode(String soapFaultCode) {
-        faultCode.setValueString(soapFaultCode);
-    }
-
-    public void setFaultCode(QName soapFaultCode) {
-        faultCode.setValue(soapFaultCode);
-    }
-
-    /**
-     * Add a reason for the fault
-     * @param text text message
-     * @param language language
-     */
-    public void addReason(String text,String language) {
-        reasons.add(text,language);
-    }
-
-    /**
-     * Add a reason for the fault in the empty "" language
-     * @param text text message
-     */
-    public void addReason(String text) {
-        addReason(text, "");
-    }
-
-    /**
-     * Add a header to the list of fault headers
-     * @param header to add.
-     */
-    public void addHeader(SOAPHeader header) {
-        headers.add(header);
-    }
-
-    /**
-     * Iterate over all of the headers
-     * @return iterator
-     */
-    public ListIterator headerIterator() {
-        return headers.listIterator();
-    }
-
-    /**
-     * Get at the headers. Useful for java1.5 iteration.
-     * @return the headers for this fault
-     */
-    public List headers() {
-        return headers;
-    }
-
     /**
      * Get the faulting node uri.
      * SOAP1.2
+     *
      * @return URI as a string or null
      */
     public String getNodeURI() {
@@ -268,25 +276,26 @@
     }
 
     /**
-     * Set the faulting node uri. SOAP1.2
+     * Set the entire detail element of the fault
+     *
+     * @param detail
      */
-    public void setNodeURI(String nodeURI) {
-        this.nodeURI = nodeURI;
+    public void setDetail(OMElement detail) {
+        this.detail = detail;
     }
 
-    /**
-     * Get the current fault detail
-     * @return om element
-     */
-    public OMElement getDetail() {
-        return detail;
+    public void setFaultCode(QName soapFaultCode) {
+        faultCode.setValue(soapFaultCode);
+    }
+
+    public void setFaultCode(String soapFaultCode) {
+        faultCode.setValueString(soapFaultCode);
     }
 
     /**
-     * Set the entire detail element of the fault
-     * @param detail
+     * Set the faulting node uri. SOAP1.2
      */
-    public void setDetail(OMElement detail) {
-        this.detail = detail;
+    public void setNodeURI(String nodeURI) {
+        this.nodeURI = nodeURI;
     }
 }

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/Constants.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/Constants.java?rev=357187&r1=357186&r2=357187&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/Constants.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/Constants.java Fri Dec 16 09:13:57 2005
@@ -1,18 +1,19 @@
 /*
- * 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.
- */
+* 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;
 
@@ -20,6 +21,7 @@
  * Class Constants
  */
 public class Constants {
+
     /**
      * Field SOAP_STYLE_RPC_ENCODED
      */
@@ -36,19 +38,19 @@
     public static final int SOAP_STYLE_DOC_LITERAL_WRAPPED = 1002;
 
     /**
-     * Field APPLICATION_SCOPE
+     * Field SESSION_SCOPE
      */
-    public static final String APPLICATION_SCOPE = "application";
+    public static final String SESSION_SCOPE = "session";
 
     /**
-     * Field SESSION_SCOPE
+     * Field SESSION_CONTEXT_PROPERTY
      */
-    public static final String SESSION_SCOPE = "session";
+    public static final String SESSION_CONTEXT_PROPERTY = "SessionContext";
 
     /**
-     * Field MESSAGE_SCOPE
+     * Field PHASE_TRANSPORT
      */
-    public static final String MESSAGE_SCOPE = "message";
+    public static final String PHASE_TRANSPORT = "transport";
 
     /**
      * Field PHASE_SERVICE
@@ -56,179 +58,140 @@
     public static final String PHASE_SERVICE = "service";
 
     /**
-     * Field PHASE_TRANSPORT
+     * Field PHASE_GLOBAL
      */
-    public static final String PHASE_TRANSPORT = "transport";
+    public static final String PHASE_GLOBAL = "global";
 
     /**
-     * Field PHASE_GLOBAL
+     * Field MESSAGE_SCOPE
      */
-    public static final String PHASE_GLOBAL = "global";
+    public static final String MESSAGE_SCOPE = "message";
 
     /**
-     * Field SESSION_CONTEXT_PROPERTY
+     * Field APPLICATION_SCOPE
      */
-    public static final String SESSION_CONTEXT_PROPERTY = "SessionContext";
+    public static final String APPLICATION_SCOPE = "application";
 
     /**
      * Field TRANSPORT_TCP
      */
     public static final String TRANSPORT_TCP = "tcp";
+    public static final String TRANSPORT_MAIL = "mail";
+    public static final String TRANSPORT_LOCAL = "local";
+    public static final String TRANSPORT_JMS = "jms";
 
     /**
      * Field TRANSPORT_HTTP
      */
     public static final String TRANSPORT_HTTP = "http";
 
-   
-
-    public static final String TRANSPORT_MAIL = "mail";
-
-    public static final String TRANSPORT_JMS = "jms";
-
-    public static final String TRANSPORT_LOCAL = "local";
-
     /**
      * Field REQUEST_URL_PREFIX
      */
     public static final String REQUEST_URL_PREFIX = "/services";
-
-    public static final String LIST_SERVICES = "listServices";
-
+    public static final String LOGOUT = "logout";
     public static final String LIST_SERVICE_FOR_MODULE_ENGAGEMENT = "listoperation";
-
-
-    /**
-     * List service for admin pages
-     */
-    public static final String ADMIN_LISTSERVICES = "listService";
-
+    public static final String LIST_SERVICES = "listServices";
+    public static final String LIST_PHASES = "listPhases";
     public static final String LIST_MODULES = "listModules";
-
     public static final String LIST_GLOABLLY_ENGAGED_MODULES = "globalModules";
-
-    public static final String LIST_PHASES = "listPhases";
-
-    public static final String ENGAGE_GLOBAL_MODULE = "engagingglobally";
-    public static final String ENGAGE_MODULE_TO_SERVICE = "engageToService";
-
+    public static final String LIST_CONTEXTS = "listContexts";
     public static final String ENGAGE_MODULE_TO_SERVICE_GROUP = "engageToServiceGroup";
-
+    public static final String ENGAGE_MODULE_TO_SERVICE = "engageToService";
+    public static final String ENGAGE_GLOBAL_MODULE = "engagingglobally";
     public static final String ADMIN_LOGIN = "adminlogin";
 
-    public static final String LIST_CONTEXTS = "listContexts";
-    public static final String LOGOUT = "logout";
-
+    /**
+     * List service for admin pages
+     */
+    public static final String ADMIN_LISTSERVICES = "listService";
     public static final String VIEW_GLOBAL_HANDLERS = "viewGlobalHandlers";
+    public static final String SELECT_SERVICE_FOR_PARA_EDIT = "selectServiceParaEdit";
     public static final String SELECT_SERVICE = "selectService";
     public static final String EDIR_SERVICE_PARA = "editServicepara";
-    public static final String SELECT_SERVICE_FOR_PARA_EDIT = "selectServiceParaEdit";
     public static final String VIEW_SERVICE_HANDLERS = "viewServiceHandlers";
-    public static final String LIST_SERVICE_GROUPS = "listServciceGroups";
+    public static final String USER_NAME = "userName";
 
+    /**
+     * Field SINGLE_SERVICE
+     */
+    public static final String SINGLE_SERVICE = "singleservice";
+    public static final String SERVLET_CONTEXT = "servletContext";
     public static final String SERVICE_MAP = "servicemap";
-
+    public static final String SERVICE_HANDLERS = "serviceHandlers";
     public static final String SERVICE_GROUP_MAP = "serviceGroupmap";
-
-    public static final String CONFIG_CONTEXT = "config_context";
-
     public static final String SERVICE = "service";
-
-    public static final String OPERATION_MAP = "operationmap";
-
-    public static final String MODULE_MAP = "modulemap";
-
     public static final String SELECT_SERVICE_TYPE = "SELECT_SERVICE_TYPE";
-
-    public static final String GLOBAL_HANDLERS = "axisconfig";
-    public static final String SERVICE_HANDLERS = "serviceHandlers";
-
+    public static final String REMOVE_SERVICE = "removeService";
     public static final String PHASE_LIST = "phaseList";
-
+    public static final String PASSWORD = "password";
+    public static final String OPERATION_MAP = "operationmap";
+    public static final String MODULE_MAP = "modulemap";
+    public static final String MODULE_ADDRESSING = "addressing";
+    public static final String LIST_SERVICE_GROUPS = "listServciceGroups";
     public static final String LIST_OPERATIONS_FOR_THE_SERVICE = "listOperations";
-
-    public static final String REMOVE_SERVICE = "removeService";
-
-    public static final String ENGAGE_STATUS = "engagestatus";
-
-    public static final String SERVLET_CONTEXT = "servletContext";
+    public static final String IS_FAULTY = "Fault";
+    public static final String GLOBAL_HANDLERS = "axisconfig";
 
     /**
      * Keys for service/module error maps
      */
     public static final String ERROR_SERVICE_MAP = "errprservicemap";
     public static final String ERROR_MODULE_MAP = "errormodulesmap";
-
-    public static final String IS_FAULTY = "Fault";
-
-    public static final String MODULE_ADDRESSING = "addressing";
-
-    public static final String USER_NAME = "userName";
-    public static final String PASSWORD = "password";
+    public static final String ENGAGE_STATUS = "engagestatus";
+    public static final String CONFIG_CONTEXT = "config_context";
+    public static final String WSDL_CONTENT = "wsdl";
+    public static final String WSA_ACTION = "wsamapping";
+    public static final String VALUE_TRUE = "true";
+    public static final String VALUE_FALSE = "false";
+    public static final String TESTING_PATH = "target/test-resources/";
+    public static final String TESTING_REPOSITORY = TESTING_PATH + "samples";
+    public static final char SERVICE_NAME_SPLIT_CHAR = ':';
+    public static final String SERVICE_GROUP_ID = "ServiceGroupId";
+    public static final String RESPONSE_WRITTEN = "CONTENT_WRITTEN";
 
     /**
-     * Field SINGLE_SERVICE
+     * Transport Info
      */
-    public static final String SINGLE_SERVICE = "singleservice";
-    public static final String WSDL_CONTENT = "wsdl";
+    public static final String OUT_TRANSPORT_INFO = "OutTransportInfo";
 
     /**
      * Field METHOD_NAME_ESCAPE_CHARACTER
      */
     public static final char METHOD_NAME_ESCAPE_CHARACTER = '?';
-
     public static final String LOGGED = "Logged";
-
-
-    public static final char SERVICE_NAME_SPLIT_CHAR =':';
-    
-    /** Addressing Constants */
-    public static final String ADDRESSING_ACTION = "WS-Addressing:Action";
-    public static final String ADDRESSING_FAULT_TO = "WS-Addressing:FaultTo" ;
-    public static final String ADDRESSING_FROM = "WS-Addressing:From" ;
+    public static final String CONTAINER_MANAGED = "ContainerManaged";
+    public static final String AXIS2_NAMESPACE_URI =
+            "http://ws.apache.org/namespaces/axis2";
+    public static final String AXIS2_NAMESPACE_PREFIX = "axis2";
+    public static final String ADDRESSING_TO = "WS-Addressing:To";
+    public static final String ADDRESSING_REPLY_TO = "WS-Addressing:ReplyTo";
+    public static final String ADDRESSING_RELATES_TO = "WS-Addressing:RelatesTo";
     public static final String ADDRESSING_MESSAGE_ID = "WS-Addressing:MessageId";
-    public static final String ADDRESSING_RELATES_TO = "WS-Addressing:RelatesTo" ;
-    public static final String ADDRESSING_REPLY_TO = "WS-Addressing:ReplyTo" ;
-    public static final String ADDRESSING_TO = "WS-Addressing:To" ;
+    public static final String ADDRESSING_FROM = "WS-Addressing:From";
+    public static final String ADDRESSING_FAULT_TO = "WS-Addressing:FaultTo";
 
-    /** Transport Info */
-    public static final String OUT_TRANSPORT_INFO = "OutTransportInfo";
+    /**
+     * Addressing Constants
+     */
+    public static final String ADDRESSING_ACTION = "WS-Addressing:Action";
 
     public static interface Configuration {
         public static final String ENABLE_REST = "enableREST";
-        public static final String ENABLE_REST_THROUGH_GET="restThroughGet";
+        public static final String ENABLE_REST_THROUGH_GET = "restThroughGet";
+
         // globally enable MTOM
         public static final String ENABLE_MTOM = "enableMTOM";
-        public static final String ATTACHMENT_TEMP_DIR = "attachmentDIR";
         public static final String CACHE_ATTACHMENTS = "cacheAttachments";
+        public static final String ATTACHMENT_TEMP_DIR = "attachmentDIR";
         public static final String FILE_SIZE_THRESHOLD = "sizeThreshold";
-
         public static final String HTTP_METHOD_GET = "GET";
         public static final String HTTP_METHOD = "HTTP_METHOD";
         public static final String HTTP_METHOD_POST = "POST";
-        public static final String CONTENT_TYPE = "ContentType";
 
         // we need to some times send the message as multipart/related, even if there is no MTOM stuff in the envelope.
         public static final String FORCE_MIME = "ForceMimeBoundary";
-
+        public static final String CONTENT_TYPE = "ContentType";
         public static final String IS_USING_SEPARATE_LISTENER = "IsUsingSeparateListener";
     }
-
-    public static final String VALUE_TRUE = "true";
-    public static final String VALUE_FALSE = "false";
-    public static final String CONTAINER_MANAGED = "ContainerManaged";
-    public static final String RESPONSE_WRITTEN = "CONTENT_WRITTEN";
-    public static final String WSA_ACTION = "wsamapping";
-
-
-    public static final String TESTING_PATH = "target/test-resources/";
-    
-    public static final String TESTING_REPOSITORY = TESTING_PATH + "samples";
-
-    public static final String AXIS2_NAMESPACE_PREFIX = "axis2";
-    public static final String AXIS2_NAMESPACE_URI = "http://ws.apache.org/namespaces/axis2";
-
-    public static final String SERVICE_GROUP_ID = "ServiceGroupId";
-
-
 }

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/AddressingConstants.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/AddressingConstants.java?rev=357187&r1=357186&r2=357187&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/AddressingConstants.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/AddressingConstants.java Fri Dec 16 09:13:57 2005
@@ -1,21 +1,21 @@
 /*
- * 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.
- */
+* 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.addressing;
 
+package org.apache.axis2.addressing;
 
 /**
  * Interface AddressingConstants
@@ -27,52 +27,55 @@
     public static final String WSA_RELATES_TO = "RelatesTo";
     public static final String WSA_RELATES_TO_RELATIONSHIP_TYPE = "RelationshipType";
     public static final String WSA_TO = "To";
-    public static final String WSA_FROM = "From";
     public static final String WSA_REPLY_TO = "ReplyTo";
+    public static final String WSA_FROM = "From";
     public static final String WSA_FAULT_TO = "FaultTo";
     public static final String WSA_ACTION = "Action";
+    public static final String EPR_SERVICE_NAME = "ServiceName";
+    public static final String EPR_REFERENCE_PARAMETERS = "ReferenceParameters";
 
     // ====================== Common EPR Elements ============================
     public static final String EPR_ADDRESS = "Address";
-    public static final String EPR_REFERENCE_PARAMETERS = "ReferenceParameters";
-    public static final String EPR_SERVICE_NAME = "ServiceName";
-
-    // ======================================================================
-
-    public interface Submission {
-        // ====================== Addressing Submission Version Constants ===================
-        public static final String WSA_NAMESPACE = "http://schemas.xmlsoap.org/ws/2004/08/addressing";
-        public static final String WSA_RELATES_TO_RELATIONSHIP_TYPE_DEFAULT_VALUE = "wsa:Reply";
-        public static final String WSA_ANONYMOUS_URL = "http://schemas.xmlsoap.org/ws/2004/08/addressing/role/anonymous";
-
-        public static final String EPR_REFERENCE_PROPERTIES = "ReferenceProperties";
-        public static final String EPR_PORT_TYPE = "PortType";
-        public static final String EPR_SERVICE_NAME_PORT_NAME = "PortName";
-        // ==================================================================================
-
-    }
+    public static final String WS_ADDRESSING_VERSION = "WSAddressingVersion";
+    public static final String WSA_DEFAULT_PREFIX = "wsa";
+    public static final String PARAM_SERVICE_GROUP_CONTEXT_ID =
+            "ServiceGroupContextIdFromAddressing";
 
     public interface Final {
-        // ====================== Addressing 1.0 Final Version Constants ====================
-        public static final String WSA_NAMESPACE = "http://www.w3.org/2005/08/addressing";
-        public static final String WSA_RELATES_TO_RELATIONSHIP_TYPE_DEFAULT_VALUE = "http://www.w3.org/2005/08/addressing/reply";
-        public static final String WSA_ANONYMOUS_URL = "http://www.w3.org/2005/08/addressing/anonymous";
 
+        // ====================== Addressing 1.0 Final Version Constants ====================
+        public static final String WSA_NAMESPACE =
+                "http://www.w3.org/2005/08/addressing";
+        public static final String WSA_RELATES_TO_RELATIONSHIP_TYPE_DEFAULT_VALUE =
+                "http://www.w3.org/2005/08/addressing/reply";
         public static final String WSA_IS_REFERENCE_PARAMETER_ATTRIBUTE = "IsReferenceParameter";
+        public static final String WSA_ANONYMOUS_URL =
+                "http://www.w3.org/2005/08/addressing/anonymous";
         public static final String WSA_TYPE_ATTRIBUTE_VALUE = "true";
-
-        public static final String WSA_INTERFACE_NAME = "InterfaceName";
         public static final String WSA_SERVICE_NAME_ENDPOINT_NAME = "EndpointName";
         public static final String WSA_POLICIES = "Policies";
         public static final String WSA_METADATA = "Metadata";
+
         // ==================================================================================
 
+        public static final String WSA_INTERFACE_NAME = "InterfaceName";
     }
 
 
-    public static final String WS_ADDRESSING_VERSION = "WSAddressingVersion";
-    public static final String WSA_DEFAULT_PREFIX = "wsa";
+    // ======================================================================
+    public interface Submission {
+
+        // ====================== Addressing Submission Version Constants ===================
+        public static final String WSA_NAMESPACE =
+                "http://schemas.xmlsoap.org/ws/2004/08/addressing";
+        public static final String WSA_RELATES_TO_RELATIONSHIP_TYPE_DEFAULT_VALUE = "wsa:Reply";
+        public static final String WSA_ANONYMOUS_URL =
+                "http://schemas.xmlsoap.org/ws/2004/08/addressing/role/anonymous";
+        public static final String EPR_SERVICE_NAME_PORT_NAME = "PortName";
 
-    public static final String PARAM_SERVICE_GROUP_CONTEXT_ID = "ServiceGroupContextIdFromAddressing";
+        // ==================================================================================
 
+        public static final String EPR_REFERENCE_PROPERTIES = "ReferenceProperties";
+        public static final String EPR_PORT_TYPE = "PortType";
+    }
 }

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/AnyContentType.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/AnyContentType.java?rev=357187&r1=357186&r2=357187&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/AnyContentType.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/AnyContentType.java Fri Dec 16 09:13:57 2005
@@ -1,18 +1,19 @@
 /*
- * 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.
- */
+* 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.addressing;
 
@@ -48,6 +49,10 @@
         valueHolder.put(name, value);
     }
 
+    public Iterator getKeys() {
+        return valueHolder.keySet().iterator();
+    }
+
     /**
      * Method getReferenceValue
      *
@@ -55,9 +60,5 @@
      */
     public String getReferenceValue(QName name) {
         return (String) valueHolder.get(name);
-    }
-
-    public Iterator getKeys() {
-        return valueHolder.keySet().iterator();
     }
 }

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/EndpointReference.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/EndpointReference.java?rev=357187&r1=357186&r2=357187&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/EndpointReference.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/EndpointReference.java Fri Dec 16 09:13:57 2005
@@ -1,18 +1,20 @@
 /*
- * 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.
- */
+* 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.addressing;
 
 import org.apache.axis2.om.OMAbstractFactory;
@@ -32,16 +34,16 @@
 
     // Commons properties
     private String address;
+
+    // Properties from WS-A Final
+    private OMElement metaData;
+    private OMElement policy;
+    private QName portType;
     private Map referenceParameters;
 
     // Properties from WS-A Submission version
     private Map referenceProperties;
-    private QName portType;
     private ServiceName serviceName;
-    private OMElement policy;
-
-    // Properties from WS-A Final
-    private OMElement metaData;
 
     /**
      * @param address
@@ -51,43 +53,75 @@
     }
 
     /**
-     * Method getAddress
+     * @param omElement
      */
-    public String getAddress() {
-        return address;
+    public void addReferenceParameter(OMElement omElement) {
+        if (omElement == null) {
+            return;
+        }
+
+        if (referenceParameters == null) {
+            referenceParameters = new HashMap();
+        }
+
+        referenceParameters.put(omElement.getQName(), omElement);
     }
 
     /**
-     * Method setAddress
-     *
-     * @param address
+     * @param qname
+     * @param value - the text of the OMElement. Remember that this is a convenient method for the user,
+     *              which has limited capability. If you want more power use @See EndpointReference#addReferenceParameter(OMElement)
      */
-    public void setAddress(String address) {
-        this.address = address;
+    public void addReferenceParameter(QName qname, String value) {
+        if (qname == null) {
+            return;
+        }
+
+        OMElement omElement = OMAbstractFactory.getOMFactory().createOMElement(qname, null);
+
+        omElement.setText(value);
+        addReferenceParameter(omElement);
     }
 
     /**
-     * Method getServiceName
+     * Remember that reference properties are only supported in WS-A Submission version.
+     *
+     * @param omElement
      */
-    public ServiceName getServiceName() {
-        return serviceName;
+    public void addReferenceProperty(OMElement omElement) {
+        if (omElement == null) {
+            return;
+        }
+
+        if (referenceProperties == null) {
+            referenceProperties = new HashMap();
+        }
+
+        referenceProperties.put(omElement.getQName(), omElement);
     }
 
     /**
-     * Method setServiceName
+     * Remember that reference properties are only supported in WS-A Submission version.
      *
-     * @param serviceName
+     * @param qname
+     * @param value
      */
-    public void setServiceName(ServiceName serviceName) {
-        this.serviceName = serviceName;
-    }
+    public void addReferenceProperty(QName qname, String value) {
+        if (qname == null) {
+            return;
+        }
 
-    public OMElement getPolicy() {
-        return policy;
+        OMElement omElement = OMAbstractFactory.getOMFactory().createOMElement(qname, null);
+
+        omElement.setText(value);
+        addReferenceProperty(omElement);
     }
 
-    public void setPolicy(OMElement policy) {
-        this.policy = policy;
+    /**
+     * Method getAddress
+     */
+    public String getAddress() {
+        return address;
     }
 
     /**
@@ -102,16 +136,6 @@
     }
 
     /**
-     * Set a Map with QName as the key and an OMElement
-     * as the value
-     *
-     * @param referenceParameters
-     */
-    public void setReferenceParameters(Map referenceParameters) {
-        this.referenceParameters = referenceParameters;
-    }
-
-    /**
      * This will return a Map of reference properties with QName as the key and an OMElement
      * as the value
      *
@@ -122,89 +146,72 @@
         return referenceProperties;
     }
 
-    /**
-     * Set a Map with QName as the key and an OMElement
-     * as the value
-     *
-     * @param referenceProperties
-     */
-    public void setReferenceProperties(HashMap referenceProperties) {
-        this.referenceProperties = referenceProperties;
+    public OMElement getMetaData() {
+        return metaData;
+    }
+
+    public OMElement getPolicy() {
+        return policy;
     }
 
     public QName getPortType() {
         return portType;
     }
 
-    public void setPortType(QName portType) {
-        this.portType = portType;
+    /**
+     * Method getServiceName
+     */
+    public ServiceName getServiceName() {
+        return serviceName;
     }
 
-    public OMElement getMetaData() {
-        return metaData;
+    /**
+     * Method setAddress
+     *
+     * @param address
+     */
+    public void setAddress(String address) {
+        this.address = address;
     }
 
     public void setMetaData(OMElement metaData) {
         this.metaData = metaData;
     }
 
+    public void setPolicy(OMElement policy) {
+        this.policy = policy;
+    }
 
-    /**
-     * @param qname
-     * @param value - the text of the OMElement. Remember that this is a convenient method for the user,
-     *              which has limited capability. If you want more power use @See EndpointReference#addReferenceParameter(OMElement)
-     */
-    public void addReferenceParameter(QName qname, String value) {
-        if (qname == null) {
-            return;
-        }
-        OMElement omElement = OMAbstractFactory.getOMFactory().createOMElement(qname, null);
-        omElement.setText(value);
-        addReferenceParameter(omElement);
+    public void setPortType(QName portType) {
+        this.portType = portType;
     }
 
     /**
-     * @param omElement
+     * Set a Map with QName as the key and an OMElement
+     * as the value
+     *
+     * @param referenceParameters
      */
-    public void addReferenceParameter(OMElement omElement) {
-        if (omElement == null) {
-            return;
-        }
-        if (referenceParameters == null) {
-            referenceParameters = new HashMap();
-        }
-        referenceParameters.put(omElement.getQName(), omElement);
+    public void setReferenceParameters(Map referenceParameters) {
+        this.referenceParameters = referenceParameters;
     }
 
     /**
-     * Remember that reference properties are only supported in WS-A Submission version.
+     * Set a Map with QName as the key and an OMElement
+     * as the value
      *
-     * @param qname
-     * @param value
+     * @param referenceProperties
      */
-    public void addReferenceProperty(QName qname, String value) {
-        if (qname == null) {
-            return;
-        }
-        OMElement omElement = OMAbstractFactory.getOMFactory().createOMElement(qname, null);
-        omElement.setText(value);
-        addReferenceProperty(omElement);
+    public void setReferenceProperties(HashMap referenceProperties) {
+        this.referenceProperties = referenceProperties;
     }
 
     /**
-     * Remember that reference properties are only supported in WS-A Submission version.
+     * Method setServiceName
      *
-     * @param omElement
+     * @param serviceName
      */
-    public void addReferenceProperty(OMElement omElement) {
-        if (omElement == null) {
-            return;
-        }
-        if (referenceProperties == null) {
-            referenceProperties = new HashMap();
-        }
-        referenceProperties.put(omElement.getQName(), omElement);
+    public void setServiceName(ServiceName serviceName) {
+        this.serviceName = serviceName;
     }
-
-
 }

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/MessageInformationHeaders.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/MessageInformationHeaders.java?rev=357187&r1=357186&r2=357187&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/MessageInformationHeaders.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/MessageInformationHeaders.java Fri Dec 16 09:13:57 2005
@@ -1,18 +1,20 @@
 /*
- * 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.
- */
+* 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.addressing;
 
 import org.apache.axis2.om.OMElement;
@@ -27,42 +29,43 @@
 public class MessageInformationHeaders implements Serializable {
 
     /**
-     * The address of the intended receiver of the message. This is mandatory
+     * Field action
      */
-    private EndpointReference to;
+    private String action;
 
     /**
-     * Reference of the endpoint where the message originated from
+     * identifies the intended receiver for faults related to the message
      */
-    private EndpointReference from;
+    private EndpointReference faultTo;
 
     /**
-     * Pair of values that indicate how this message related to another message
+     * Reference of the endpoint where the message originated from
      */
-    private RelatesTo relatesTo;
+    private EndpointReference from;
 
     /**
-     * identifies the intended receiver for replies to the message
+     * Field messageId
      */
-    private EndpointReference replyTo;
+    private String messageId;
+    private ArrayList referenceParameters;
 
     /**
-     * identifies the intended receiver for faults related to the message
+     * Pair of values that indicate how this message related to another message
      */
-    private EndpointReference faultTo;
+    private RelatesTo relatesTo;
 
     /**
-     * Field action
+     * identifies the intended receiver for replies to the message
      */
-    private String action;
+    private EndpointReference replyTo;
 
     /**
-     * Field messageId
+     * The address of the intended receiver of the message. This is mandatory
      */
-    private String messageId;
-
-    private ArrayList referenceParameters;
+    private EndpointReference to;
 
+    public MessageInformationHeaders() {
+    }
 
     /**
      * Addressing Header MUST have a to and an action
@@ -70,13 +73,17 @@
      * @param wsaTo
      * @param action
      */
-    public MessageInformationHeaders(EndpointReference wsaTo,
-                                               String action) {
+    public MessageInformationHeaders(EndpointReference wsaTo, String action) {
         this.to = wsaTo;
         this.action = action;
     }
 
-    public MessageInformationHeaders() {
+    public void addReferenceParameter(OMElement referenceParameter) {
+        if (referenceParameters == null) {
+            referenceParameters = new ArrayList(5);
+        }
+
+        referenceParameters.add(referenceParameter);
     }
 
     /**
@@ -88,23 +95,18 @@
         throw new UnsupportedOperationException();
     }
 
-    // ------------------- Setters and Getters --------------------------------------
-
     /**
-     * Method getTo
+     * Method getAction
      */
-    public EndpointReference getTo() {
-
-        return to;
+    public String getAction() {
+        return action;
     }
 
     /**
-     * Method setTo
-     *
-     * @param to
+     * Method getFaultTo
      */
-    public void setTo(EndpointReference to) {
-        this.to = to;
+    public EndpointReference getFaultTo() {
+        return faultTo;
     }
 
     /**
@@ -115,37 +117,46 @@
     }
 
     /**
-     * Method setFrom
-     *
-     * @param from
+     * Method getMessageId
      */
-    public void setFrom(EndpointReference from) {
-        this.from = from;
+    public String getMessageId() {
+        return messageId;
+    }
+
+    public ArrayList getReferenceParameters() {
+        return referenceParameters;
+    }
+
+    /**
+     * Method getRelatesTo
+     */
+    public RelatesTo getRelatesTo() {
+        return relatesTo;
     }
 
     /**
      * Method getReplyTo
      */
     public EndpointReference getReplyTo() {
-
         return replyTo;
     }
 
+    // ------------------- Setters and Getters --------------------------------------
+
     /**
-     * Method setReplyTo
-     *
-     * @param replyTo
+     * Method getTo
      */
-    public void setReplyTo(EndpointReference replyTo) {
-        this.replyTo = replyTo;
+    public EndpointReference getTo() {
+        return to;
     }
 
     /**
-     * Method getFaultTo
+     * Method setAction
+     *
+     * @param action
      */
-    public EndpointReference getFaultTo() {
-
-        return faultTo;
+    public void setAction(String action) {
+        this.action = action;
     }
 
     /**
@@ -158,26 +169,12 @@
     }
 
     /**
-     * Method getAction
-     */
-    public String getAction() {
-        return action;
-    }
-
-    /**
-     * Method setAction
+     * Method setFrom
      *
-     * @param action
-     */
-    public void setAction(String action) {
-        this.action = action;
-    }
-
-    /**
-     * Method getMessageId
+     * @param from
      */
-    public String getMessageId() {
-        return messageId;
+    public void setFrom(EndpointReference from) {
+        this.from = from;
     }
 
     /**
@@ -189,12 +186,8 @@
         this.messageId = messageId;
     }
 
-    /**
-     * Method getRelatesTo
-     */
-    public RelatesTo getRelatesTo() {
-
-        return relatesTo;
+    public void setReferenceParameters(ArrayList referenceParameters) {
+        this.referenceParameters = referenceParameters;
     }
 
     /**
@@ -203,24 +196,26 @@
      * @param relatesTo
      */
     public void setRelatesTo(RelatesTo relatesTo) {
-
         this.relatesTo = relatesTo;
     }
 
-    public ArrayList getReferenceParameters() {
-        return referenceParameters;
-    }
-
-    public void setReferenceParameters(ArrayList referenceParameters) {
-        this.referenceParameters = referenceParameters;
+    /**
+     * Method setReplyTo
+     *
+     * @param replyTo
+     */
+    public void setReplyTo(EndpointReference replyTo) {
+        this.replyTo = replyTo;
     }
 
-    public void addReferenceParameter(OMElement referenceParameter) {
-        if (referenceParameters == null) {
-            referenceParameters = new ArrayList(5);
-        }
-        referenceParameters.add(referenceParameter);
+    /**
+     * Method setTo
+     *
+     * @param to
+     */
+    public void setTo(EndpointReference to) {
+        this.to = to;
     }
 
     // --------------------------------------------------------------------------------------------
-}
\ No newline at end of file
+}

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/RelatesTo.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/RelatesTo.java?rev=357187&r1=357186&r2=357187&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/RelatesTo.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/RelatesTo.java Fri Dec 16 09:13:57 2005
@@ -1,18 +1,19 @@
 /*
- * 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.
- */
+* 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.addressing;
 
@@ -21,11 +22,7 @@
 /**
  * Class RelatesTo
  */
-public class RelatesTo implements Serializable{
-    /**
-     * Field value
-     */
-    private String value;
+public class RelatesTo implements Serializable {
 
     /**
      * Field relationshipType
@@ -33,6 +30,11 @@
     private String relationshipType;
 
     /**
+     * Field value
+     */
+    private String value;
+
+    /**
      * Constructor RelatesTo
      *
      * @param address
@@ -53,26 +55,17 @@
     }
 
     /**
-     * Method getValue
-     */
-    public String getValue() {
-        return value;
-    }
-
-    /**
-     * Method setValue
-     *
-     * @param value
+     * Method getRelationshipType
      */
-    public void setValue(String value) {
-        this.value = value;
+    public String getRelationshipType() {
+        return relationshipType;
     }
 
     /**
-     * Method getRelationshipType
+     * Method getValue
      */
-    public String getRelationshipType() {
-        return relationshipType;
+    public String getValue() {
+        return value;
     }
 
     /**
@@ -82,5 +75,14 @@
      */
     public void setRelationshipType(String relationshipType) {
         this.relationshipType = relationshipType;
+    }
+
+    /**
+     * Method setValue
+     *
+     * @param value
+     */
+    public void setValue(String value) {
+        this.value = value;
     }
 }

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/ServiceName.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/ServiceName.java?rev=357187&r1=357186&r2=357187&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/ServiceName.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/addressing/ServiceName.java Fri Dec 16 09:13:57 2005
@@ -1,18 +1,20 @@
 /*
- * 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.
- */
+* 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.addressing;
 
 import javax.xml.namespace.QName;
@@ -21,6 +23,7 @@
  * Class ServiceName
  */
 public class ServiceName {
+
     /**
      * Field name
      */
@@ -55,19 +58,19 @@
     }
 
     /**
+     * Method getPortName
+     */
+    public String getPortName() {
+        return portName;
+    }
+
+    /**
      * Method setName
      *
      * @param name
      */
     public void setName(QName name) {
         this.name = name;
-    }
-
-    /**
-     * Method getPortName
-     */
-    public String getPortName() {
-        return portName;
     }
 
     /**