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 gd...@apache.org on 2007/03/04 19:17:07 UTC

svn commit: r514453 [5/26] - in /webservices/axis2/trunk/java/modules/kernel: src/org/apache/axis2/ src/org/apache/axis2/addressing/ src/org/apache/axis2/addressing/wsdl/ src/org/apache/axis2/builder/ src/org/apache/axis2/client/ src/org/apache/axis2/c...

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/MessageContextConstants.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/MessageContextConstants.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/MessageContextConstants.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/MessageContextConstants.java Sun Mar  4 10:16:54 2007
@@ -23,11 +23,11 @@
      */
     public static final String TRANSPORT_URL = "TransportURL";
 
-    
+
     /**
      * @deprecated please use org.apache.axis2.transport.http.HTTPConstants.CHUNKED *
      */
-    public static final String CHUNKED="__CHUNKED__";
+    public static final String CHUNKED = "__CHUNKED__";
 
     /**
      * @deprecated please use org.apache.axis2.transport.http.HTTPConstants.HTTP_PROTOCOL_VERSION *

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/OperationContext.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/OperationContext.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/OperationContext.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/OperationContext.java Sun Mar  4 10:16:54 2007
@@ -61,11 +61,11 @@
     private static final String myClassName = "OperationContext";
 
     /**
-     * An ID which can be used to correlate operations on an instance of 
+     * An ID which can be used to correlate operations on an instance of
      * this object in the log files
      */
-    private String logCorrelationIDString = myClassName +"@"+ UUIDGenerator.getUUID();
-    
+    private String logCorrelationIDString = myClassName + "@" + UUIDGenerator.getUUID();
+
 
     /**
      * @serial The serialization version ID tracks the version of the class.
@@ -76,13 +76,13 @@
      * Refer to the "serialVer" utility to compute a serialization
      * version ID.
      */
-    private  static final long serialVersionUID = -7264782778333554350L;
+    private static final long serialVersionUID = -7264782778333554350L;
 
     /**
-     * @serial Tracks the revision level of a class to identify changes to the 
+     * @serial Tracks the revision level of a class to identify changes to the
      * class definition that are compatible to serialization/externalization.
      * If a class definition changes, then the serialization/externalization
-     * of the class is affected. 
+     * of the class is affected.
      * Refer to the writeExternal() and readExternal() methods.
      */
     // supported revision levels, add a new level to manage compatible changes
@@ -114,7 +114,7 @@
     //----------------------------------------------------------------
     // MetaData for data to be restored in activate after readExternal
     //----------------------------------------------------------------
-    
+
     /**
      * Indicates whether the message context has been reconstituted
      * and needs to have its object references reconciled
@@ -132,19 +132,19 @@
      * activate to match up with an existing object
      */
     private transient MetaDataEntry metaAxisOperation = null;
-    
+
     /**
      * The AxisService metadata will be used during
      * activate to match up with an existing object
      */
     private transient MetaDataEntry metaAxisService = null;
-    
+
     /**
      * The ServiceContext metadata will be used during
      * activate to match up with an existing object
      */
     private transient ServiceContext metaParent = null;
-    
+
 
     /**
      * This is used to hold information about message context objects
@@ -156,7 +156,7 @@
 
     /**
      * This is used to hold temporarily any message context objects
-     * that were isolated from the messageContexts map. 
+     * that were isolated from the messageContexts map.
      */
     private transient HashMap isolatedMessageContexts = null;
 
@@ -171,7 +171,7 @@
     //----------------------------------------------------------------
 
     /**
-     *  Simple constructor
+     * Simple constructor
      */
     public OperationContext() {
         super(null);
@@ -233,7 +233,8 @@
      */
     public AxisOperation getAxisOperation() {
         if (needsToBeReconciled && !suppressWarnings) {
-            log.warn(logCorrelationIDString+":getAxisOperation(): ****WARNING**** OperationContext.activate(configurationContext) needs to be invoked.");
+            log.warn(logCorrelationIDString +
+                    ":getAxisOperation(): ****WARNING**** OperationContext.activate(configurationContext) needs to be invoked.");
         }
 
         return axisOperation;
@@ -297,29 +298,28 @@
         this.key = key;
     }
 
-
     /* ===============================================================
-     * Externalizable support 
-     * ===============================================================
-     */
-    
+    * Externalizable support
+    * ===============================================================
+    */
+
 
     /**
      * Save the contents of this object.
      * <p/>
      * NOTE: Transient fields and static fields are not saved.
-     *       Also, objects that represent "static" data are
-     *       not saved, except for enough information to be
-     *       able to find matching objects when the message
-     *       context is re-constituted.
+     * Also, objects that represent "static" data are
+     * not saved, except for enough information to be
+     * able to find matching objects when the message
+     * context is re-constituted.
      *
-     * @param out    The stream to write the object contents to
+     * @param out The stream to write the object contents to
      * @throws IOException
      */
     public void writeExternal(ObjectOutput out) throws IOException {
         //---------------------------------------------------------
-        // in order to handle future changes to the message 
-        // context definition, be sure to maintain the 
+        // in order to handle future changes to the message
+        // context definition, be sure to maintain the
         // object level identifiers
         //---------------------------------------------------------
         // serialization version ID
@@ -336,9 +336,10 @@
 
         out.writeBoolean(isComplete);
 
-        ObjectStateUtils.writeString(out, key, logCorrelationIDString+".key");
+        ObjectStateUtils.writeString(out, key, logCorrelationIDString + ".key");
 
-        ObjectStateUtils.writeString(out, logCorrelationIDString, logCorrelationIDString+".logCorrelationIDString");
+        ObjectStateUtils.writeString(out, logCorrelationIDString,
+                                     logCorrelationIDString + ".logCorrelationIDString");
 
         //---------------------------------------------------------
         // properties
@@ -351,27 +352,28 @@
             tmpHashMap = new HashMap(tmpMap);
         }
 
-        ObjectStateUtils.writeHashMap(out, tmpHashMap, logCorrelationIDString+".properties");
-
+        ObjectStateUtils.writeHashMap(out, tmpHashMap, logCorrelationIDString + ".properties");
 
         //---------------------------------------------------------
         // AxisOperation axisOperation
         //---------------------------------------------------------
-        String axisOpMarker = logCorrelationIDString+".axisOperation";
+        String axisOpMarker = logCorrelationIDString + ".axisOperation";
         ObjectStateUtils.writeString(out, axisOpMarker, axisOpMarker);
 
         if (axisOperation == null) {
             out.writeBoolean(ObjectStateUtils.EMPTY_OBJECT);
         } else {
             out.writeBoolean(ObjectStateUtils.ACTIVE_OBJECT);
-            metaAxisOperation = new MetaDataEntry(axisOperation.getClass().getName(), axisOperation.getName().toString());
-            ObjectStateUtils.writeObject(out, metaAxisOperation, logCorrelationIDString+".metaAxisOperation");
+            metaAxisOperation = new MetaDataEntry(axisOperation.getClass().getName(),
+                                                  axisOperation.getName().toString());
+            ObjectStateUtils.writeObject(out, metaAxisOperation,
+                                         logCorrelationIDString + ".metaAxisOperation");
         }
 
         // save the meta data for the corresponding axis service to better
-        // match up the axis operation 
+        // match up the axis operation
 
-        String axisServMarker = logCorrelationIDString+".metaAxisService";
+        String axisServMarker = logCorrelationIDString + ".metaAxisService";
         ObjectStateUtils.writeString(out, axisServMarker, axisServMarker);
 
         AxisService axisService = (AxisService) axisOperation.getParent();
@@ -380,18 +382,19 @@
             out.writeBoolean(ObjectStateUtils.EMPTY_OBJECT);
         } else {
             out.writeBoolean(ObjectStateUtils.ACTIVE_OBJECT);
-            metaAxisService = new MetaDataEntry(axisService.getClass().getName(), axisService.getName());
-            ObjectStateUtils.writeObject(out, metaAxisService, logCorrelationIDString+".metaAxisService");
+            metaAxisService =
+                    new MetaDataEntry(axisService.getClass().getName(), axisService.getName());
+            ObjectStateUtils
+                    .writeObject(out, metaAxisService, logCorrelationIDString + ".metaAxisService");
         }
-        
 
         //---------------------------------------------------------
-        // parent 
+        // parent
         //---------------------------------------------------------
         ServiceContext myParent = this.getServiceContext();
 
-        ObjectStateUtils.writeObject(out, myParent, logCorrelationIDString+".parent ServiceContext"); 
-
+        ObjectStateUtils
+                .writeObject(out, myParent, logCorrelationIDString + ".parent ServiceContext");
 
         //---------------------------------------------------------
         // HashMap messageContexts table
@@ -399,13 +402,12 @@
 
         // NOTES: The assumption is that the table contains message contexts
         // that are in the OperationContext hierarchy.  To reduce overlap
-        // of object information that is being saved, extract the 
+        // of object information that is being saved, extract the
         // message context objects from the hierachy before saving.
         // When the OperationContext is restored, the "slimmed down"
         // message context objects are plugged back into the hierachy
         // using the restored OperationContext as a basis.
 
-
         // first deal with the original messageContexts table
         HashMap tmpMsgCtxMap = null;
 
@@ -430,7 +432,8 @@
                 if (isolatedMessageContexts != null) {
                     if (!isolatedMessageContexts.isEmpty()) {
                         // see if the message context was previously isolated
-                        MessageContext valueIsolated = (MessageContext) isolatedMessageContexts.get(keyObj);
+                        MessageContext valueIsolated =
+                                (MessageContext) isolatedMessageContexts.get(keyObj);
 
                         if (valueIsolated != null) {
                             String idIsol = valueIsolated.getMessageID();
@@ -447,7 +450,7 @@
 
                 if (addToWorkingSet) {
                     // put the meta data entry in the list
-                    workingSet.put(keyObj,value);
+                    workingSet.put(keyObj, value);
                 }
 
             }
@@ -469,19 +472,22 @@
                 MessageContext modifiedValue2 = value2.extractCopyMessageContext();
 
                 // put the modified entry in the list
-                tmpMsgCtxMap.put(keyObj2,modifiedValue2);
+                tmpMsgCtxMap.put(keyObj2, modifiedValue2);
 
                 // trace point
-                log.trace(logCorrelationIDString+":writeExternal():  getting working set entry  key ["+keyObj2+"]   message context ID["+modifiedValue2.getMessageID()+"]");
+                log.trace(logCorrelationIDString +
+                        ":writeExternal():  getting working set entry  key [" + keyObj2 +
+                        "]   message context ID[" + modifiedValue2.getMessageID() + "]");
             }
 
         }
 
-        ObjectStateUtils.writeHashMap(out, tmpMsgCtxMap, logCorrelationIDString+".messageContexts working set");
+        ObjectStateUtils.writeHashMap(out, tmpMsgCtxMap,
+                                      logCorrelationIDString + ".messageContexts working set");
 
         // next, deal with the metadata table of messageContexts
-        ObjectStateUtils.writeHashMap(out, metaMessageContextMap, logCorrelationIDString+".metaMessageContextMap metadata table");
-
+        ObjectStateUtils.writeHashMap(out, metaMessageContextMap, logCorrelationIDString +
+                ".metaMessageContextMap metadata table");
 
         //---------------------------------------------------------
         // done
@@ -494,21 +500,22 @@
      * Restore the contents of the object that was previously saved.
      * <p/>
      * NOTE: The field data must read back in the same order and type
-     * as it was written.  Some data will need to be validated when 
+     * as it was written.  Some data will need to be validated when
      * resurrected.
      *
-     * @param in    The stream to read the object contents from 
+     * @param in The stream to read the object contents from
      * @throws IOException
      * @throws ClassNotFoundException
      */
     public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
         // set the flag to indicate that the message context is being
-        // reconstituted and will need to have certain object references 
+        // reconstituted and will need to have certain object references
         // to be reconciled with the current engine setup
         needsToBeReconciled = true;
 
         // trace point
-        log.trace(myClassName+":readExternal():  BEGIN  bytes available in stream ["+in.available()+"]  ");
+        log.trace(myClassName + ":readExternal():  BEGIN  bytes available in stream [" +
+                in.available() + "]  ");
 
         //---------------------------------------------------------
         // object level identifiers
@@ -518,7 +525,7 @@
         long suid = in.readLong();
 
         // revision ID
-        int  revID = in.readInt();
+        int revID = in.readInt();
 
         // make sure the object data is in a version we can handle
         if (suid != serialVersionUID) {
@@ -530,7 +537,6 @@
             throw new ClassNotFoundException(ObjectStateUtils.UNSUPPORTED_REVID);
         }
 
-
         //---------------------------------------------------------
         // various simple fields
         //---------------------------------------------------------
@@ -540,25 +546,26 @@
 
         isComplete = in.readBoolean();
 
-        key = ObjectStateUtils.readString(in,"OperationContext.key"); 
+        key = ObjectStateUtils.readString(in, "OperationContext.key");
 
-        logCorrelationIDString = ObjectStateUtils.readString(in, "OperationContext.logCorrelationIDString");
+        logCorrelationIDString =
+                ObjectStateUtils.readString(in, "OperationContext.logCorrelationIDString");
 
         // trace point
-        log.trace(myClassName+":readExternal():  reading input stream for ["+logCorrelationIDString+"]  ");
+        log.trace(myClassName + ":readExternal():  reading input stream for [" +
+                logCorrelationIDString + "]  ");
 
         //---------------------------------------------------------
         // properties
         //---------------------------------------------------------
 
-        HashMap tmpHashMap = ObjectStateUtils.readHashMap(in,"OperationContext.properties");
+        HashMap tmpHashMap = ObjectStateUtils.readHashMap(in, "OperationContext.properties");
 
         properties = new HashMap();
         if (tmpHashMap != null) {
             setProperties(tmpHashMap);
         }
 
-
         //---------------------------------------------------------
         // axis operation meta data
         //---------------------------------------------------------
@@ -571,34 +578,33 @@
         boolean metaAxisOperationIsActive = in.readBoolean();
 
         if (metaAxisOperationIsActive == ObjectStateUtils.ACTIVE_OBJECT) {
-            metaAxisOperation = (MetaDataEntry) ObjectStateUtils.readObject(in, "OperationContext.metaAxisOperation");
+            metaAxisOperation = (MetaDataEntry) ObjectStateUtils
+                    .readObject(in, "OperationContext.metaAxisOperation");
         } else {
             metaAxisOperation = null;
         }
 
-
         // axisService is not usable until the meta data has been reconciled
 
         ObjectStateUtils.readString(in, "OperationContext.axisService");
-        
+
         boolean metaAxisServiceIsActive = in.readBoolean();
 
         if (metaAxisServiceIsActive == ObjectStateUtils.ACTIVE_OBJECT) {
-            metaAxisService = (MetaDataEntry) ObjectStateUtils.readObject(in, "OperationContext.metaAxisService");
+            metaAxisService = (MetaDataEntry) ObjectStateUtils
+                    .readObject(in, "OperationContext.metaAxisService");
         } else {
             metaAxisService = null;
         }
-        
-
 
         //---------------------------------------------------------
-        // parent 
+        // parent
         //---------------------------------------------------------
 
-        // ServiceContext is not usable until it has been activated 
+        // ServiceContext is not usable until it has been activated
 
-        metaParent = (ServiceContext) ObjectStateUtils.readObject(in, "OperationContext.parent ServiceContext");
-        
+        metaParent = (ServiceContext) ObjectStateUtils
+                .readObject(in, "OperationContext.parent ServiceContext");
 
         //---------------------------------------------------------
         // HashMap messageContexts table
@@ -607,9 +613,11 @@
         // set to empty until this can be activiated
         messageContexts = new HashMap();
 
-        workingSet = ObjectStateUtils.readHashMap(in, logCorrelationIDString+".messageContexts working set");
+        workingSet = ObjectStateUtils
+                .readHashMap(in, logCorrelationIDString + ".messageContexts working set");
 
-        metaMessageContextMap = ObjectStateUtils.readHashMap(in, logCorrelationIDString+".metaMessageContextMap metadata table");
+        metaMessageContextMap = ObjectStateUtils
+                .readHashMap(in, logCorrelationIDString + ".metaMessageContextMap metadata table");
 
         //---------------------------------------------------------
         // done
@@ -618,7 +626,7 @@
 
     }
 
-    
+
     /**
      * This method checks to see if additional work needs to be
      * done in order to complete the object reconstitution.
@@ -627,8 +635,8 @@
      * from the active engine. The configurationContext is used
      * to help this object to plug back into the engine's
      * configuration and deployment objects.
-     * 
-     * @param cc     The configuration context object representing the active configuration
+     *
+     * @param cc The configuration context object representing the active configuration
      */
     public void activate(ConfigurationContext cc) {
         // see if there's any work to do
@@ -637,34 +645,38 @@
             return;
         }
 
-        // get the axis configuration 
+        // get the axis configuration
         AxisConfiguration axisConfig = cc.getAxisConfiguration();
 
-
         // We previously saved metaAxisService; restore it
         AxisService axisService = null;
 
         if (metaAxisService != null) {
-            axisService = ObjectStateUtils.findService(axisConfig, metaAxisService.getClassName(), metaAxisService.getQNameAsString());
+            axisService = ObjectStateUtils.findService(axisConfig, metaAxisService.getClassName(),
+                                                       metaAxisService.getQNameAsString());
         }
 
         // We previously saved metaAxisOperation; restore it
         if (metaAxisOperation != null) {
             if (axisService != null) {
-                this.axisOperation = ObjectStateUtils.findOperation(axisService, metaAxisOperation.getClassName(), metaAxisOperation.getQName());
+                this.axisOperation = ObjectStateUtils.findOperation(axisService,
+                                                                    metaAxisOperation.getClassName(),
+                                                                    metaAxisOperation.getQName());
             } else {
-                this.axisOperation = ObjectStateUtils.findOperation(axisConfig, metaAxisOperation.getClassName(), metaAxisOperation.getQName());
+                this.axisOperation = ObjectStateUtils.findOperation(axisConfig,
+                                                                    metaAxisOperation.getClassName(),
+                                                                    metaAxisOperation.getQName());
             }
         }
-        
+
         // the parent ServiceContext object was saved
-        // either use the restored object or sync up with 
+        // either use the restored object or sync up with
         // an existing ServiceContext object
         if (metaParent != null) {
             // find out if a copy of the ServiceContext object exists on this
             // engine where this OperationContext is being restored/activated
             // if so, use that object instead of the restored object
-            // in order to make sure that future changes to service-level 
+            // in order to make sure that future changes to service-level
             // properties are preserved for future operations
             String groupName = metaParent.getGroupName();
             String serviceName = metaParent.getName();
@@ -680,8 +692,9 @@
 
             if (existingSC == null) {
                 // we couldn't find the ServiceContext via the ServiceContextGroup
-                // try via the set of existing operation contexts 
-                OperationContext existingOC = cc.findOperationContext(getOperationName(), serviceName, groupName);
+                // try via the set of existing operation contexts
+                OperationContext existingOC =
+                        cc.findOperationContext(getOperationName(), serviceName, groupName);
 
                 if (existingOC != null) {
                     existingSC = (ServiceContext) existingOC.getParent();
@@ -693,7 +706,7 @@
                 // use the restored object
                 metaParent.activate(cc);
 
-                // set parent 
+                // set parent
                 this.setParent(metaParent);
             } else {
                 // switch over to the existing object
@@ -703,42 +716,43 @@
                 // to the existing ServiceContext
                 // Should the copy be a non-destructive one?  That is,
                 // if the key already exists in the properties table of the
-                // existing object, should the value be overwritten from the 
+                // existing object, should the value be overwritten from the
                 // restored ojbect? For now, the decision is that the state
                 // that has been preserved for a saved context object is
                 // is important to be restored.
-                metaParent.putContextProperties(existingSC,true);
+                metaParent.putContextProperties(existingSC, true);
             }
         } else {
             // set parent  to null
             this.setParent(metaParent);
         }
 
-
         // reseed the operation context map
 
         ServiceContext serv = getServiceContext();
-        ConfigurationContext activeCC ;
+        ConfigurationContext activeCC;
         if (serv != null) {
             activeCC = serv.getConfigurationContext();
         } else {
             activeCC = cc;
         }
 
-        if(key!=null){
-            // make sure this OperationContext object is registered in the 
+        if (key != null) {
+            // make sure this OperationContext object is registered in the
             // list maintained by the ConfigurationContext object
             boolean registrationSuceeded = activeCC.registerOperationContext(key, this);
-            if(!registrationSuceeded){
+            if (!registrationSuceeded) {
                 // trace point
-                log.trace(logCorrelationIDString+":activate():  OperationContext key ["+key+"] already exists in ConfigurationContext map.  This OperationContext ["+this.toString()+"] was not added to the table.");
+                log.trace(logCorrelationIDString + ":activate():  OperationContext key [" + key +
+                        "] already exists in ConfigurationContext map.  This OperationContext [" +
+                        this.toString() + "] was not added to the table.");
             }
         }
-        
+
         //-------------------------------------------------------
         // update the modified entries in the messageContexts table
         //-------------------------------------------------------
-        // NOTE: an entry in the metaMessageContextMap must wait 
+        // NOTE: an entry in the metaMessageContextMap must wait
         // for its corresponding active message context object
         // to call this operation context object so we don't
         // need to handle the metaMessagecontextMap table here
@@ -752,12 +766,13 @@
                 String keyObj = (String) itKeys.next();
 
                 // get the message context associated with that label
-                MessageContext value = (MessageContext) workingSet.get((Object)keyObj);
+                MessageContext value = (MessageContext) workingSet.get((Object) keyObj);
 
-                // activate that object 
+                // activate that object
                 if (value != null) {
                     // trace point
-                    log.trace(logCorrelationIDString+":activate():  key ["+keyObj+"]  message id ["+value.getMessageID()+"]");
+                    log.trace(logCorrelationIDString + ":activate():  key [" + keyObj +
+                            "]  message id [" + value.getMessageID() + "]");
 
                     suppressWarnings = true;
                     value.activateWithOperationContext(this);
@@ -774,7 +789,6 @@
             }
         }
 
-
         //-------------------------------------------------------
         // done, reset the flag
         //-------------------------------------------------------
@@ -784,16 +798,16 @@
 
     /**
      * Isolate the specified message context object
-     * to prepare for serialization.  Instead of 
+     * to prepare for serialization.  Instead of
      * saving the entire message context object,
      * just setup some metadata about the message
      * context.
      * <p/>
-     * Note: this will remove the specified 
+     * Note: this will remove the specified
      * message context object from the message context
      * table.
-     * 
-     * @param mc     The message context object
+     *
+     * @param mc The message context object
      */
     public void isolateMessageContext(MessageContext mc) {
         if (mc == null) {
@@ -838,14 +852,16 @@
                     //           key used in the original hashmap that is associated with this MessageContext
                     //                    note: this is typically something like "In", "Out", "Fault"
                     //
-                    MetaDataEntry metaData = new MetaDataEntry(value.getClass().getName(), value.getMessageID(), keyObj.toString());
+                    MetaDataEntry metaData = new MetaDataEntry(value.getClass().getName(),
+                                                               value.getMessageID(),
+                                                               keyObj.toString());
 
                     // put the meta data entry in the list
                     // note that if the entry was already in the list,
                     // this will replace that entry
-                    metaMessageContextMap.put(keyObj,metaData);
+                    metaMessageContextMap.put(keyObj, metaData);
 
-                    // don't change the original table - there's potentially lots of areas that 
+                    // don't change the original table - there's potentially lots of areas that
                     // grab the table
                     //  // now remove the original entry from the messageContexts table
                     //  messageContexts.remove(keyObj);
@@ -857,11 +873,13 @@
 
                     // note that if the entry was already in the list,
                     // this will replace that entry
-                    isolatedMessageContexts.put(keyObj,value);
-
+                    isolatedMessageContexts.put(keyObj, value);
 
                     // trace point
-                    log.trace(logCorrelationIDString+":isolateMessageContext():  set up message context id["+valueID+"]  with key ["+keyObj.toString()+"] from messageContexts table to prepare for serialization.");
+                    log.trace(logCorrelationIDString +
+                            ":isolateMessageContext():  set up message context id[" + valueID +
+                            "]  with key [" + keyObj.toString() +
+                            "] from messageContexts table to prepare for serialization.");
 
                     break;
                 }
@@ -870,19 +888,19 @@
     }
 
 
-
     /**
-     * Restore the specified MessageContext object in the 
+     * Restore the specified MessageContext object in the
      * table used to hold the message contexts associated
      * with this operation.
      *
-     * @param msg   The message context object 
+     * @param msg The message context object
      */
     public void restoreMessageContext(MessageContext msg) {
         // see if the activation has been done
         if (needsToBeReconciled) {
             // nope, need to do the activation first
-            log.trace(logCorrelationIDString+":restoreMessageContext(): *** WARNING : need to invoke activate() prior to restoring the MessageContext to the list.");
+            log.trace(logCorrelationIDString +
+                    ":restoreMessageContext(): *** WARNING : need to invoke activate() prior to restoring the MessageContext to the list.");
 
             return;
         }
@@ -895,13 +913,14 @@
 
         if (msgID == null) {
             // can't identify message context
-            log.trace(logCorrelationIDString+":restoreMessageContext(): *** WARNING : MessageContext does not have a message ID.");
+            log.trace(logCorrelationIDString +
+                    ":restoreMessageContext(): *** WARNING : MessageContext does not have a message ID.");
             return;
         }
 
-        // first check the metaMessageContextMap to see if 
+        // first check the metaMessageContextMap to see if
         // the specified message context object matches any
-        // of the metadata entries.  
+        // of the metadata entries.
 
         if ((metaMessageContextMap != null) && (!metaMessageContextMap.isEmpty())) {
             Iterator itMeta = metaMessageContextMap.keySet().iterator();
@@ -910,7 +929,7 @@
                 String keyM = (String) itMeta.next();
 
                 MetaDataEntry valueM = (MetaDataEntry) metaMessageContextMap.get(keyM);
-                String valueM_ID ;
+                String valueM_ID;
 
                 if (valueM != null) {
                     valueM_ID = valueM.getQNameAsString();
@@ -928,39 +947,41 @@
                         // remove the metadata from the metadata table
                         metaMessageContextMap.remove(keyM);
 
-                        log.trace(logCorrelationIDString+":restoreMessageContext():  restored   label ["+label+"]    message ID ["+msg.getMessageID()+"]");
+                        log.trace(logCorrelationIDString +
+                                ":restoreMessageContext():  restored   label [" + label +
+                                "]    message ID [" + msg.getMessageID() + "]");
 
                         break;
                     }
                 }
             }
         } else
-        // see if we can put the msg directly in the messageContexts table
+            // see if we can put the msg directly in the messageContexts table
             if ((messageContexts != null) && (!messageContexts.isEmpty())) {
-            Iterator itList = messageContexts.keySet().iterator();
+                Iterator itList = messageContexts.keySet().iterator();
 
                 while (itList.hasNext()) {
-                String key = (String) itList.next();
+                    String key = (String) itList.next();
 
-                MessageContext value = (MessageContext) messageContexts.get(key);
-                String valueID ;
+                    MessageContext value = (MessageContext) messageContexts.get(key);
+                    String valueID;
 
                     if (value != null) {
-                    valueID = value.getMessageID();
+                        valueID = value.getMessageID();
 
                         if (msgID.equals(valueID)) {
-                        // update the entry
-                        messageContexts.put(key, msg);
+                            // update the entry
+                            messageContexts.put(key, msg);
+                        }
                     }
                 }
             }
-        }
 
     }
 
     /**
      * Get the name associated with the operation.
-     * 
+     *
      * @return The name String
      */
     public String getOperationName() {
@@ -978,7 +999,7 @@
 
     /**
      * Get the name associated with the service.
-     * 
+     *
      * @return The name String
      */
     public String getServiceName() {
@@ -999,7 +1020,7 @@
 
     /**
      * Get the name associated with the service group.
-     * 
+     *
      * @return The name String
      */
     public String getServiceGroupName() {
@@ -1020,19 +1041,19 @@
 
 
     /**
-     * Compares key parts of the state from the current instance of 
-     * this class with the specified instance to see if they are 
-     * equivalent. 
+     * Compares key parts of the state from the current instance of
+     * this class with the specified instance to see if they are
+     * equivalent.
      * <p/>
      * This differs from the java.lang.Object.equals() method in
-     * that the equals() method generally looks at both the 
+     * that the equals() method generally looks at both the
      * object identity (location in memory) and the object state
      * (data).
      * <p/>
-     * 
-     * @param ctx  The object to compare with
+     *
+     * @param ctx The object to compare with
      * @return TRUE if this object is equivalent with the specified object
-     *              that is, key fields match
+     *         that is, key fields match
      *         FALSE, otherwise
      */
     public boolean isEquivalent(OperationContext ctx) {
@@ -1056,17 +1077,17 @@
 
     /**
      * Get the ID associated with this object instance.
-     * 
+     *
      * @return A string that can be output to a log file as an identifier
-     * for this object instance.  It is suitable for matching related log
-     * entries. 
+     *         for this object instance.  It is suitable for matching related log
+     *         entries.
      */
     public String getLogCorrelationIDString() {
         return logCorrelationIDString;
     }
-    
+
     public ConfigurationContext getRootContext() {
         return this.getConfigurationContext();
     }
-    
+
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/OperationContextFactory.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/OperationContextFactory.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/OperationContextFactory.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/OperationContextFactory.java Sun Mar  4 10:16:54 2007
@@ -30,12 +30,15 @@
     public static OperationContext createOperationContext(int mepURI, AxisOperation axisOp,
                                                           ServiceContext serviceContext)
             throws AxisFault {
-        if ((WSDLConstants.MEP_CONSTANT_IN_OUT == mepURI) || (WSDLConstants.MEP_CONSTANT_IN_ONLY == mepURI)
+        if ((WSDLConstants.MEP_CONSTANT_IN_OUT == mepURI) ||
+                (WSDLConstants.MEP_CONSTANT_IN_ONLY == mepURI)
                 || (WSDLConstants.MEP_CONSTANT_IN_OPTIONAL_OUT == mepURI)
-                || (WSDLConstants.MEP_CONSTANT_ROBUST_IN_ONLY == mepURI) || (WSDLConstants.MEP_CONSTANT_OUT_ONLY == mepURI)
-                || (WSDLConstants.MEP_CONSTANT_OUT_IN == mepURI) || (WSDLConstants.MEP_CONSTANT_OUT_OPTIONAL_IN == mepURI)
+                || (WSDLConstants.MEP_CONSTANT_ROBUST_IN_ONLY == mepURI) ||
+                (WSDLConstants.MEP_CONSTANT_OUT_ONLY == mepURI)
+                || (WSDLConstants.MEP_CONSTANT_OUT_IN == mepURI) ||
+                (WSDLConstants.MEP_CONSTANT_OUT_OPTIONAL_IN == mepURI)
                 || (WSDLConstants.MEP_CONSTANT_ROBUST_OUT_ONLY == mepURI)) {
-            return ContextFactory.createOperationContext(axisOp,serviceContext);
+            return ContextFactory.createOperationContext(axisOp, serviceContext);
         } else {
             throw new AxisFault(Messages.getMessage("unSupportedMEP", "ID is " + mepURI));
         }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/SelfManagedDataManager.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/SelfManagedDataManager.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/SelfManagedDataManager.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/SelfManagedDataManager.java Sun Mar  4 10:16:54 2007
@@ -21,21 +21,21 @@
 import java.io.IOException;
 
 /**
- * An interface for use by a message handler to allow 
+ * An interface for use by a message handler to allow
  * it to save and restore any message-specific data.
  * <p/>
- * A handler can have message-specific data that 
+ * A handler can have message-specific data that
  * needs to be associated the message being processed.
- * The handler can keep this message-specific data 
- * in the Messagecontext object by adding the 
- * data to the user data table via the 
- * MessageContext method.  When the MessageContext 
+ * The handler can keep this message-specific data
+ * in the Messagecontext object by adding the
+ * data to the user data table via the
+ * MessageContext method.  When the MessageContext
  * object is saved (for example, to persistent storage),
  * and restored, this interface <B>SelfManagedDataManager</B>
  * provides a way for the handler to save and restore
  * the handler's message-specific data.
- * 
- * @see org.apache.axis2.context.MessageContext
+ *
+ * @see MessageContext
  */
 public interface SelfManagedDataManager {
 
@@ -53,8 +53,8 @@
      * Note that data stored by the implementor in the MessageContext object's SelfManagedData
      * list is retrievable by calling the MessageContext.getSelfManagedData() method
      * for EACH key/value pair.
-     * 
-     * @param mc     the MessageContext that is being saved
+     *
+     * @param mc the MessageContext that is being saved
      * @return The saved data in the output stream. Note that the
      *         format of the data in the output stream is defined
      *         by the implementor.
@@ -68,12 +68,13 @@
      * Implementors will receive the data they had previously saved in the
      * serializeSelfManagedData() method. Implementors are responsible for
      * reconstituting their message-specific data.
-     * 
-     * @param data   ByteArrayInputStream consisting of the data that this handler had previously saved
-     * @param mc     the MessageContext object being restored
+     *
+     * @param data ByteArrayInputStream consisting of the data that this handler had previously saved
+     * @param mc   the MessageContext object being restored
      * @throws IOException
      */
-    public void deserializeSelfManagedData(ByteArrayInputStream data, MessageContext mc) throws IOException;
+    public void deserializeSelfManagedData(ByteArrayInputStream data, MessageContext mc)
+            throws IOException;
 
 
     /**
@@ -81,9 +82,9 @@
      * after the deserializeSelfManagedData() method.
      * <p/>
      * Implementors use this method to re-establish transient message-specific data,
-     * particularly if the implementor did not save any user data in the 
+     * particularly if the implementor did not save any user data in the
      * serializeSelfManagedData() method.
-     * 
+     *
      * @param mc the MessageContext object being restored
      */
     public void restoreTransientData(MessageContext mc);

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/ServiceContext.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/ServiceContext.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/ServiceContext.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/ServiceContext.java Sun Mar  4 10:16:54 2007
@@ -53,11 +53,11 @@
     private static final String myClassName = "ServiceContext";
 
     /**
-     * An ID which can be used to correlate operations on an instance of 
+     * An ID which can be used to correlate operations on an instance of
      * this object in the log files
      */
-    private String logCorrelationIDString = myClassName +"@"+ UUIDGenerator.getUUID();
-    
+    private String logCorrelationIDString = myClassName + "@" + UUIDGenerator.getUUID();
+
 
     /**
      * @serial The serialization version ID tracks the version of the class.
@@ -71,10 +71,10 @@
     private static final long serialVersionUID = 8265625275015738957L;
 
     /**
-     * @serial Tracks the revision level of a class to identify changes to the 
+     * @serial Tracks the revision level of a class to identify changes to the
      * class definition that are compatible to serialization/externalization.
      * If a class definition changes, then the serialization/externalization
-     * of the class is affected. 
+     * of the class is affected.
      * Refer to the writeExternal() and readExternal() methods.
      */
     // supported revision levels, add a new level to manage compatible changes
@@ -107,7 +107,7 @@
     //----------------------------------------------------------------
     // MetaData for data to be restored in activate after readExternal
     //----------------------------------------------------------------
-    
+
     /**
      * Indicates whether the message context has been reconstituted
      * and needs to have its object references reconciled
@@ -119,14 +119,13 @@
      * activate to match up with an existing object
      */
     private transient MetaDataEntry metaAxisService = null;
-    
+
     /**
      * The ServiceGroupContext object will be used during
-     * activate to finish its restoration 
+     * activate to finish its restoration
      */
-    private transient ServiceGroupContext  metaParent = null;
-    
-    
+    private transient ServiceGroupContext metaParent = null;
+
     //----------------------------------------------------------------
     // end MetaData section
     //----------------------------------------------------------------
@@ -195,7 +194,7 @@
                     lm.addListener(trsin, false);
                 } else {
                     throw new AxisFault(Messages.getMessage("transportnotfound",
-                            transport));
+                                                            transport));
                 }
             }
             if (!lm.isStopped()) {
@@ -255,7 +254,7 @@
      * <p/>
      * Note: this name is from the corresponding
      * AxisService object.
-     * 
+     *
      * @return The name string, or null if no name can be found
      */
     public String getName() {
@@ -272,9 +271,9 @@
 
 
     /**
-     * Returns a name associated with the ServiceGroupContext 
+     * Returns a name associated with the ServiceGroupContext
      * associated with this ServiceContext.
-     * 
+     *
      * @return The name string, or null if no name can be found
      */
     public String getGroupName() {
@@ -293,18 +292,18 @@
      * Externalizable support 
      * ===============================================================
      */
-    
+
 
     /**
      * Save the contents of this object.
      * <p/>
      * NOTE: Transient fields and static fields are not saved.
-     *       Also, objects that represent "static" data are
-     *       not saved, except for enough information to be
-     *       able to find matching objects when the message
-     *       context is re-constituted.
+     * Also, objects that represent "static" data are
+     * not saved, except for enough information to be
+     * able to find matching objects when the message
+     * context is re-constituted.
      *
-     * @param out    The stream to write the object contents to
+     * @param out The stream to write the object contents to
      * @throws IOException
      */
     public void writeExternal(ObjectOutput out) throws IOException {
@@ -327,7 +326,8 @@
 
         out.writeBoolean(cachingOperationContext);
 
-        ObjectStateUtils.writeString(out, logCorrelationIDString, logCorrelationIDString+".logCorrelationIDString");
+        ObjectStateUtils.writeString(out, logCorrelationIDString,
+                                     logCorrelationIDString + ".logCorrelationIDString");
 
         // put some try..catch blocks around the following objects
         // so that the writing to the output stream continues
@@ -354,7 +354,6 @@
             // so just consume the exception for now
         }
 
-
         //---------------------------------------------------------
         // properties
         //---------------------------------------------------------
@@ -368,7 +367,6 @@
 
         ObjectStateUtils.writeHashMap(out, tmpHashMap, "ServiceContext.properties");
 
-
         //---------------------------------------------------------
         // AxisService
         //---------------------------------------------------------
@@ -380,10 +378,10 @@
             out.writeBoolean(ObjectStateUtils.EMPTY_OBJECT);
         } else {
             out.writeBoolean(ObjectStateUtils.ACTIVE_OBJECT);
-            metaAxisService = new MetaDataEntry(axisService.getClass().getName(), axisService.getName());
+            metaAxisService =
+                    new MetaDataEntry(axisService.getClass().getName(), axisService.getName());
             ObjectStateUtils.writeObject(out, metaAxisService, "ServiceContext.metaAxisService");
         }
-        
 
         //---------------------------------------------------------
         // parent 
@@ -401,10 +399,10 @@
      * Restore the contents of the object that was previously saved.
      * <p/>
      * NOTE: The field data must read back in the same order and type
-     * as it was written.  Some data will need to be validated when 
+     * as it was written.  Some data will need to be validated when
      * resurrected.
      *
-     * @param in    The stream to read the object contents from 
+     * @param in The stream to read the object contents from
      * @throws IOException
      * @throws ClassNotFoundException
      */
@@ -414,10 +412,9 @@
         // to be reconciled with the current engine setup
         needsToBeReconciled = true;
 
-
         // trace point
-        log.trace(myClassName+":readExternal():  BEGIN  bytes available in stream ["+in.available()+"]  ");
-
+        log.trace(myClassName + ":readExternal():  BEGIN  bytes available in stream [" +
+                in.available() + "]  ");
 
         //---------------------------------------------------------
         // object level identifiers
@@ -427,7 +424,7 @@
         long suid = in.readLong();
 
         // revision ID
-        int  revID = in.readInt();
+        int revID = in.readInt();
 
         // make sure the object data is in a version we can handle
         if (suid != serialVersionUID) {
@@ -439,7 +436,6 @@
             throw new ClassNotFoundException(ObjectStateUtils.UNSUPPORTED_REVID);
         }
 
-
         //---------------------------------------------------------
         // various simple fields
         //---------------------------------------------------------
@@ -449,11 +445,12 @@
 
         cachingOperationContext = in.readBoolean();
 
-        logCorrelationIDString = ObjectStateUtils.readString(in, myClassName+".logCorrelationIDString");
+        logCorrelationIDString =
+                ObjectStateUtils.readString(in, myClassName + ".logCorrelationIDString");
 
         // trace point
-        log.trace(myClassName+":readExternal():  reading input stream for ["+logCorrelationIDString+"]  ");
-
+        log.trace(myClassName + ":readExternal():  reading input stream for [" +
+                logCorrelationIDString + "]  ");
 
         // EndpointReference targetEPR
         targetEPR = (EndpointReference) ObjectStateUtils.readObject(in, "ServiceContext.targetEPR");
@@ -461,19 +458,17 @@
         // EndpointReference myEPR
         myEPR = (EndpointReference) ObjectStateUtils.readObject(in, "ServiceContext.myEPR");
 
-
         //---------------------------------------------------------
         // properties
         //---------------------------------------------------------
 
-        HashMap tmpHashMap = ObjectStateUtils.readHashMap(in,"ServiceContext.properties");
+        HashMap tmpHashMap = ObjectStateUtils.readHashMap(in, "ServiceContext.properties");
 
         properties = new HashMap();
         if (tmpHashMap != null) {
             setProperties(tmpHashMap);
         }
 
-
         //---------------------------------------------------------
         // AxisService
         //---------------------------------------------------------
@@ -481,16 +476,15 @@
         // axisService is not usable until the meta data has been reconciled
 
         ObjectStateUtils.readString(in, "ServiceContext.axisService");
-        
+
         boolean metaAxisServiceIsActive = in.readBoolean();
 
         if (metaAxisServiceIsActive == ObjectStateUtils.ACTIVE_OBJECT) {
-            metaAxisService = (MetaDataEntry) ObjectStateUtils.readObject(in, "ServiceContext.metaAxisService");
+            metaAxisService = (MetaDataEntry) ObjectStateUtils
+                    .readObject(in, "ServiceContext.metaAxisService");
         } else {
             metaAxisService = null;
         }
-        
-
 
         //---------------------------------------------------------
         // parent 
@@ -498,8 +492,8 @@
 
         // ServiceGroupContext is not usable until it has been activated 
 
-        metaParent = (ServiceGroupContext) ObjectStateUtils.readObject(in, "ServiceContext.parent ServiceGroupContext");
-        
+        metaParent = (ServiceGroupContext) ObjectStateUtils
+                .readObject(in, "ServiceContext.parent ServiceGroupContext");
 
         //---------------------------------------------------------
         // other
@@ -513,7 +507,7 @@
         //---------------------------------------------------------
     }
 
-    
+
     /**
      * This method checks to see if additional work needs to be
      * done in order to complete the object reconstitution.
@@ -522,8 +516,8 @@
      * from the active engine. The configurationContext is used
      * to help this object to plug back into the engine's
      * configuration and deployment objects.
-     * 
-     * @param cc     The configuration context object representing the active configuration
+     *
+     * @param cc The configuration context object representing the active configuration
      */
     public void activate(ConfigurationContext cc) {
         // see if there's any work to do
@@ -542,10 +536,10 @@
         axisService = null;
 
         if (metaAxisService != null) {
-            axisService = ObjectStateUtils.findService(axisConfig, metaAxisService.getClassName(), metaAxisService.getQNameAsString());
+            axisService = ObjectStateUtils.findService(axisConfig, metaAxisService.getClassName(),
+                                                       metaAxisService.getQNameAsString());
         }
 
-
         // the parent ServiceGroupContext object was saved
         // either use the restored object or sync up with 
         // an existing ServiceGroupContext object
@@ -596,7 +590,6 @@
             serviceGroupContext.addServiceContext(this);
         }
 
-
         //-------------------------------------------------------
         // done, reset the flag
         //-------------------------------------------------------
@@ -610,13 +603,13 @@
 
     }
 
-    /**                         
-     * This will do a copy of the properties from this context object 
+    /**
+     * This will do a copy of the properties from this context object
      * to the properties of the specified context object.
      *
-     * @param context The ServiceContext object to hold the merged properties
-     * @param doParentProperties  Indicates whether to go up the context hierachy 
-     *                            copy the properties at each level
+     * @param context            The ServiceContext object to hold the merged properties
+     * @param doParentProperties Indicates whether to go up the context hierachy
+     *                           copy the properties at each level
      */
     public void putContextProperties(ServiceContext context, boolean doParentProperties) {
         if (context != null) {
@@ -632,7 +625,7 @@
                 if (serviceGroupContext != null) {
                     mySGC = serviceGroupContext;
                 } else if (metaParent != null) {
-                        mySGC = metaParent;
+                    mySGC = metaParent;
                 }
 
                 if (mySGC != null) {
@@ -645,19 +638,19 @@
 
 
     /**
-     * Compares key parts of the state from the current instance of 
-     * this class with the specified instance to see if they are 
-     * equivalent. 
+     * Compares key parts of the state from the current instance of
+     * this class with the specified instance to see if they are
+     * equivalent.
      * <p/>
      * This differs from the java.lang.Object.equals() method in
-     * that the equals() method generally looks at both the 
+     * that the equals() method generally looks at both the
      * object identity (location in memory) and the object state
      * (data).
      * <p/>
-     * 
+     *
      * @param ctx
      * @return TRUE if this object is equivalent with the specified object
-     *              that is, key fields match
+     *         that is, key fields match
      *         FALSE, otherwise
      */
     public boolean isEquivalent(ServiceContext ctx) {
@@ -704,10 +697,10 @@
 
     /**
      * Get the ID associated with this object instance.
-     * 
+     *
      * @return A string that can be output to a log file as an identifier
-     * for this object instance.  It is suitable for matching related log
-     * entries. 
+     *         for this object instance.  It is suitable for matching related log
+     *         entries.
      */
     public String getLogCorrelationIDString() {
         return logCorrelationIDString;
@@ -715,20 +708,21 @@
 
 
     /**
-     * Trace a warning message, if needed, indicating that this 
+     * Trace a warning message, if needed, indicating that this
      * object needs to be activated before accessing certain fields.
-     * 
+     *
      * @param methodname The method where the warning occurs
      */
     private void checkActivateWarning(String methodname) {
         if (needsToBeReconciled) {
-            log.warn(logCorrelationIDString+":"+methodname+"(): ****WARNING**** "+myClassName+".activate(configurationContext) needs to be invoked.");
+            log.warn(logCorrelationIDString + ":" + methodname + "(): ****WARNING**** " +
+                    myClassName + ".activate(configurationContext) needs to be invoked.");
         }
     }
 
     public ConfigurationContext getRootContext() {
         return configContext;
     }
-    
-    
+
+
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/ServiceGroupContext.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/ServiceGroupContext.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/ServiceGroupContext.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/ServiceGroupContext.java Sun Mar  4 10:16:54 2007
@@ -58,10 +58,10 @@
     private static final long serialVersionUID = 9014471144479928885L;
 
     /**
-     * @serial Tracks the revision level of a class to identify changes to the 
+     * @serial Tracks the revision level of a class to identify changes to the
      * class definition that are compatible to serialization/externalization.
      * If a class definition changes, then the serialization/externalization
-     * of the class is affected. 
+     * of the class is affected.
      * Refer to the writeExternal() and readExternal() methods.
      */
     // supported revision levels, add a new level to manage compatible changes
@@ -77,7 +77,7 @@
     //----------------------------------------------------------------
     // MetaData for data to be restored in activate after readExternal
     //----------------------------------------------------------------
-    
+
     /**
      * Indicates whether the message context has been reconstituted
      * and needs to have its object references reconciled
@@ -90,7 +90,6 @@
      * activate to match up with an existing object
      */
     private transient MetaDataEntry metaAxisServiceGroup = null;
-    
 
     //----------------------------------------------------------------
     // end MetaData section
@@ -135,7 +134,8 @@
         AxisService axisService = axisServiceGroup.getService(service.getName());
         if (axisService == null) {
             throw new AxisFault(Messages.getMessage("invalidserviceinagroup",
-                    service.getName(), axisServiceGroup.getServiceGroupName()));
+                                                    service.getName(),
+                                                    axisServiceGroup.getServiceGroupName()));
         }
         if (serviceContextMap == null) {
             serviceContextMap = new HashMap();
@@ -144,12 +144,12 @@
         if (serviceContext == null) {
             serviceContext = new ServiceContext(service, this);
             serviceContextMap.put(service.getName(), serviceContext);
-            
+
             ClusterManager clusterManager = axisService.getAxisConfiguration().getClusterManager();
-            if (clusterManager!=null) {
+            if (clusterManager != null) {
                 clusterManager.addContext(serviceContext);
             }
-            
+
         }
         return serviceContext;
     }
@@ -169,12 +169,11 @@
     }
 
 
-
     /**
      * Adds the specified service context object to the
      * lists of service contexts for this service group
      * context.
-     * 
+     *
      * @param srvctx The ServiceContext object to add
      */
     public void addServiceContext(ServiceContext srvctx) {
@@ -183,7 +182,7 @@
         }
 
         AxisService axisService = srvctx.getAxisService();
-        
+
         if (axisService == null) {
             return;
         }
@@ -202,7 +201,7 @@
      * to the specified name from the list
      * of service contexts for this service group
      * context.
-     * 
+     *
      * @param name The name associated with the ServiceContext
      * @return The ServiceContext associated with the name,
      *         or null, if none can be found
@@ -222,7 +221,7 @@
      * to the specified AxisService from the list
      * of service contexts for this service group
      * context.
-     * 
+     *
      * @return The ServiceContext associated with the AxisService
      *         or null, if none can be found
      */
@@ -238,8 +237,8 @@
         return (ServiceContext) serviceContextMap.get(axisSrv.getName());
     }
 
-    /**                         
-     * This will do a copy of the properties from this context object 
+    /**
+     * This will do a copy of the properties from this context object
      * to the properties of the specified context object.
      *
      * @param context The ServiceGroupContext object to hold the merged properties
@@ -254,23 +253,22 @@
         }
     }
 
-
     /* ===============================================================
-     * Externalizable support 
-     * ===============================================================
-     */
-    
+    * Externalizable support
+    * ===============================================================
+    */
+
 
     /**
      * Save the contents of this object.
      * <p/>
      * NOTE: Transient fields and static fields are not saved.
-     *       Also, objects that represent "static" data are
-     *       not saved, except for enough information to be
-     *       able to find matching objects when the message
-     *       context is re-constituted.
+     * Also, objects that represent "static" data are
+     * not saved, except for enough information to be
+     * able to find matching objects when the message
+     * context is re-constituted.
      *
-     * @param out    The stream to write the object contents to
+     * @param out The stream to write the object contents to
      * @throws IOException
      */
     public void writeExternal(ObjectOutput out) throws IOException {
@@ -313,7 +311,6 @@
 
         ObjectStateUtils.writeHashMap(out, tmpHashMap, "ServiceGroupContext.properties");
 
-
         //---------------------------------------------------------
         // AxisServiceGroup
         //---------------------------------------------------------
@@ -325,10 +322,11 @@
             out.writeBoolean(ObjectStateUtils.EMPTY_OBJECT);
         } else {
             out.writeBoolean(ObjectStateUtils.ACTIVE_OBJECT);
-            metaAxisServiceGroup = new MetaDataEntry(axisServiceGroup.getClass().getName(), axisServiceGroup.getServiceGroupName());
-            ObjectStateUtils.writeObject(out, metaAxisServiceGroup, "ServiceGroupContext.metaAxisServiceGroup");
+            metaAxisServiceGroup = new MetaDataEntry(axisServiceGroup.getClass().getName(),
+                                                     axisServiceGroup.getServiceGroupName());
+            ObjectStateUtils.writeObject(out, metaAxisServiceGroup,
+                                         "ServiceGroupContext.metaAxisServiceGroup");
         }
-        
 
         //---------------------------------------------------------
         // parent 
@@ -347,10 +345,10 @@
      * Restore the contents of the object that was previously saved.
      * <p/>
      * NOTE: The field data must read back in the same order and type
-     * as it was written.  Some data will need to be validated when 
+     * as it was written.  Some data will need to be validated when
      * resurrected.
      *
-     * @param in    The stream to read the object contents from 
+     * @param in The stream to read the object contents from
      * @throws IOException
      * @throws ClassNotFoundException
      */
@@ -362,14 +360,15 @@
 
         // trace point
         if (log.isTraceEnabled()) {
-            log.trace(myClassName+":readExternal():  BEGIN  bytes available in stream ["+in.available()+"]  ");
+            log.trace(myClassName + ":readExternal():  BEGIN  bytes available in stream [" +
+                    in.available() + "]  ");
         }
 
         // serialization version ID
         long suid = in.readLong();
 
         // revision ID
-        int  revID = in.readInt();
+        int revID = in.readInt();
 
         // make sure the object data is in a version we can handle
         if (suid != serialVersionUID) {
@@ -381,7 +380,6 @@
             throw new ClassNotFoundException(ObjectStateUtils.UNSUPPORTED_REVID);
         }
 
-
         //---------------------------------------------------------
         // various simple fields
         //---------------------------------------------------------
@@ -391,12 +389,11 @@
 
         id = ObjectStateUtils.readString(in, "ServiceGroupContext.id");
 
-
         //---------------------------------------------------------
         // properties
         //---------------------------------------------------------
 
-        HashMap tmpHashMap = ObjectStateUtils.readHashMap(in,"ServiceGroupContext.properties");
+        HashMap tmpHashMap = ObjectStateUtils.readHashMap(in, "ServiceGroupContext.properties");
 
         properties = new HashMap();
         if (tmpHashMap != null) {
@@ -411,16 +408,15 @@
         axisServiceGroup = null;
 
         ObjectStateUtils.readString(in, "ServiceGroupContext.axisServiceGroup");
-        
+
         boolean metaAxisServiceGrpIsActive = in.readBoolean();
 
         if (metaAxisServiceGrpIsActive == ObjectStateUtils.ACTIVE_OBJECT) {
-            metaAxisServiceGroup = (MetaDataEntry) ObjectStateUtils.readObject(in, "ServiceGroupContext.metaAxisServiceGroup");
+            metaAxisServiceGroup = (MetaDataEntry) ObjectStateUtils
+                    .readObject(in, "ServiceGroupContext.metaAxisServiceGroup");
         } else {
             metaAxisServiceGroup = null;
         }
-        
-
 
         //---------------------------------------------------------
         // parent 
@@ -432,22 +428,20 @@
         // with the existing ConfigurationContext object when
         // this object is reconstituted
 
-
         //---------------------------------------------------------
         // other
         //---------------------------------------------------------
         serviceContextMap = new HashMap();
 
-
         //---------------------------------------------------------
         // done
         //---------------------------------------------------------
 
     }
 
-    
-    /**                     
-     * Some parts of the object restored from the 
+
+    /**
+     * Some parts of the object restored from the
      * readExternal deserialization work cannot be completed until
      * we have a configurationContext.  This method checks to see
      * if additional work needs to be done in order to complete
@@ -465,7 +459,9 @@
 
         // We previously saved metaAxisServiceGroup; restore it
         if (metaAxisServiceGroup != null) {
-            axisServiceGroup = ObjectStateUtils.findServiceGroup(axisConfig, metaAxisServiceGroup.getClassName(), metaAxisServiceGroup.getQNameAsString());
+            axisServiceGroup = ObjectStateUtils.findServiceGroup(axisConfig,
+                                                                 metaAxisServiceGroup.getClassName(),
+                                                                 metaAxisServiceGroup.getQNameAsString());
         } else {
             axisServiceGroup = null;
         }
@@ -476,7 +472,6 @@
         // register with the parent
         cc.registerServiceGroupContextintoSoapSessionTable(this);
 
-
         //-------------------------------------------------------
         // done, reset the flag
         //-------------------------------------------------------
@@ -485,19 +480,19 @@
     }
 
     /**
-     * Compares key parts of the state from the current instance of 
-     * this class with the specified instance to see if they are 
-     * equivalent. 
+     * Compares key parts of the state from the current instance of
+     * this class with the specified instance to see if they are
+     * equivalent.
      * <p/>
      * This differs from the java.lang.Object.equals() method in
-     * that the equals() method generally looks at both the 
+     * that the equals() method generally looks at both the
      * object identity (location in memory) and the object state
      * (data).
      * <p/>
-     * 
-     * @param ctx  The object to compare with
+     *
+     * @param ctx The object to compare with
      * @return TRUE if this object is equivalent with the specified object
-     *              that is, key fields match
+     *         that is, key fields match
      *         FALSE, otherwise
      */
     public boolean isEquivalent(ServiceGroupContext ctx) {
@@ -521,8 +516,6 @@
             return false;
         }
 
-
-
         // TODO: consider checking the parent objects for equivalency
 
         // TODO: consider checking fields from the super class for equivalency
@@ -531,17 +524,18 @@
     }
 
     /**
-     * Trace a warning message, if needed, indicating that this 
+     * Trace a warning message, if needed, indicating that this
      * object needs to be activated before accessing certain fields.
-     * 
+     *
      * @param methodname The method where the warning occurs
      */
     private void checkActivateWarning(String methodname) {
         if (needsToBeReconciled) {
-            log.warn(myClassName+":"+methodname+"(): ****WARNING**** "+myClassName+".activate(configurationContext) needs to be invoked.");
+            log.warn(myClassName + ":" + methodname + "(): ****WARNING**** " + myClassName +
+                    ".activate(configurationContext) needs to be invoked.");
         }
     }
-    
+
     public ConfigurationContext getRootContext() {
         //parent of the ServiceGroupContext is the ConfigurationContext
         return (ConfigurationContext) this.getParent();

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/SessionContext.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/SessionContext.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/SessionContext.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/context/SessionContext.java Sun Mar  4 10:16:54 2007
@@ -98,7 +98,7 @@
     }
 
     public void addServiceGroupContext(ServiceGroupContext serviceGroupContext) {
-        String  serviceGroupID = serviceGroupContext.getDescription().getServiceGroupName();
+        String serviceGroupID = serviceGroupContext.getDescription().getServiceGroupName();
         serviceGroupContextMap.put(serviceGroupID, serviceGroupContext);
     }
 
@@ -160,22 +160,21 @@
         Iterator serviceContecxtes = serviceGroupContext.getServiceContexts();
         while (serviceContecxtes.hasNext()) {
             ServiceContext serviceContext = (ServiceContext) serviceContecxtes.next();
-                DependencyManager.destroyServiceObject(serviceContext);
+            DependencyManager.destroyServiceObject(serviceContext);
         }
     }
 
-
     /* ===============================================================
-     * Externalizable support
-     * ===============================================================
-     */
+    * Externalizable support
+    * ===============================================================
+    */
 
     /**
      * Save the contents of this object.
      * <p/>
      * NOTE: Transient fields and static fields are not saved.
      *
-     * @param out    The stream to write the object contents to
+     * @param out The stream to write the object contents to
      * @throws IOException
      */
     public void writeExternal(ObjectOutput out) throws IOException {
@@ -208,7 +207,6 @@
 
         ObjectStateUtils.writeString(out, cookieID, "SessionContext.cookieID");
 
-
         //---------------------------------------------------------
         // properties
         //---------------------------------------------------------
@@ -222,8 +220,6 @@
 
         ObjectStateUtils.writeHashMap(out, tmpHashMap, "SessionContext.properties");
 
-
-
         //---------------------------------------------------------
         // "nested"
         //---------------------------------------------------------
@@ -243,21 +239,22 @@
      * as it was written.  Some data will need to be validated when
      * resurrected.
      *
-     * @param in    The stream to read the object contents from
+     * @param in The stream to read the object contents from
      * @throws IOException
      * @throws ClassNotFoundException
      */
     public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
         // trace point
         if (log.isTraceEnabled()) {
-            log.trace(myClassName+":readExternal():  BEGIN  bytes available in stream ["+in.available()+"]  ");
+            log.trace(myClassName + ":readExternal():  BEGIN  bytes available in stream [" +
+                    in.available() + "]  ");
         }
 
         // serialization version ID
         long suid = in.readLong();
 
         // revision ID
-        int  revID = in.readInt();
+        int revID = in.readInt();
 
         // make sure the object data is in a version we can handle
         if (suid != serialVersionUID) {
@@ -269,7 +266,6 @@
             throw new ClassNotFoundException(ObjectStateUtils.UNSUPPORTED_REVID);
         }
 
-
         //---------------------------------------------------------
         // various simple fields
         //---------------------------------------------------------
@@ -280,19 +276,17 @@
 
         cookieID = ObjectStateUtils.readString(in, "SessionContext.cookieID");
 
-
         //---------------------------------------------------------
         // properties
         //---------------------------------------------------------
 
-        HashMap tmpHashMap = ObjectStateUtils.readHashMap(in,"SessionContext.properties");
+        HashMap tmpHashMap = ObjectStateUtils.readHashMap(in, "SessionContext.properties");
 
         properties = new HashMap();
         if (tmpHashMap != null) {
             setProperties(tmpHashMap);
         }
 
-
         //---------------------------------------------------------
         // "nested"
         //---------------------------------------------------------
@@ -317,6 +311,5 @@
         return null;
     }
 
-    
 
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/dataretrieval/AxisDataLocator.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/dataretrieval/AxisDataLocator.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/dataretrieval/AxisDataLocator.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/dataretrieval/AxisDataLocator.java Sun Mar  4 10:16:54 2007
@@ -18,27 +18,28 @@
 import org.apache.axis2.context.MessageContext;
 
 /**
- * <p>AxisDataLocator interface defines getData API for retrieving data particularly 
- * metadata like WSDL, Policy, Schema. Web Service engines that have different methods in 
+ * <p>AxisDataLocator interface defines getData API for retrieving data particularly
+ * metadata like WSDL, Policy, Schema. Web Service engines that have different methods in
  * storing metadata or different types of data to retrieve may code their version of
  * Data Locator(s)by implementing the AxisDataLocator interface. Axis 2 support
- * Data Locator plugin by configuring in Axis2.xml or services.xml. </p>  
+ * Data Locator plugin by configuring in Axis2.xml or services.xml. </p>
  */
 
 public interface AxisDataLocator {
-    
+
 
     /**
      * Retrieves and returns data based on the specified request.
-     * 
+     *
      * @param request    The {@link DataRetrievalRequest} allow to specify parameters
-     *            about the request, and additional information to process the
-     *            request.
+     *                   about the request, and additional information to process the
+     *                   request.
      * @param msgContext The {@link MessageContext} from the original request.
      * @return {@link Data}[] for the request.
      * @throws DataRetrievalException
      */
-    
-    public Data[] getData(DataRetrievalRequest request, MessageContext msgContext) throws DataRetrievalException;
-    
+
+    public Data[] getData(DataRetrievalRequest request, MessageContext msgContext)
+            throws DataRetrievalException;
+
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/dataretrieval/AxisDataLocatorImpl.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/dataretrieval/AxisDataLocatorImpl.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/dataretrieval/AxisDataLocatorImpl.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/dataretrieval/AxisDataLocatorImpl.java Sun Mar  4 10:16:54 2007
@@ -27,24 +27,24 @@
 import java.util.Iterator;
 
 /**
- * The Default Axis2 Data Locator implementation 
+ * The Default Axis2 Data Locator implementation
  */
 
 public class AxisDataLocatorImpl implements AxisDataLocator {
     private static final Log log = LogFactory.getLog(AxisDataLocatorImpl.class);
 
     // HashMap to cache Data elements defined in ServiceData. 
-    private  HashMap dataMap=new HashMap(); 
-    
+    private HashMap dataMap = new HashMap();
+
     private AxisService axisService;
-    
-    
+
+
     /**
      * Constructor
      *
      * @throws DataRetrievalException
      */
-    public AxisDataLocatorImpl(AxisService in_axisService) throws  DataRetrievalException{
+    public AxisDataLocatorImpl(AxisService in_axisService) throws DataRetrievalException {
         super();
         axisService = in_axisService;
     }
@@ -53,54 +53,55 @@
      * Retrieves and returns data based on the specified request.
      */
     public Data[] getData(DataRetrievalRequest request,
-            MessageContext msgContext) throws DataRetrievalException{
+                          MessageContext msgContext) throws DataRetrievalException {
         Data[] data = null;
         String dialect = request.getDialect();
         String identifier = request.getIdentifier();
         String key = dialect;
         ArrayList dataList = new ArrayList();
-        if (identifier != null){
+        if (identifier != null) {
             key = key + identifier;
             if (dataMap.get(key) != null) {
                 dataList.add(dataMap.get(key));
-        }
+            }
         } else {
-           dataList = getDataList(dialect);
+            dataList = getDataList(dialect);
         }
 
-        
+
         AxisDataLocator dataLocator = DataLocatorFactory
-                .createDataLocator(dialect, (ServiceData[])dataList.toArray(new ServiceData[0]));
-    
+                .createDataLocator(dialect, (ServiceData[]) dataList.toArray(new ServiceData[0]));
+
         if (dataLocator != null) {
             try {
-               data = dataLocator.getData(request, msgContext);
+                data = dataLocator.getData(request, msgContext);
             }
-            catch (Throwable e){
-                log.info("getData request failed for dialect, " + dialect, e);    
+            catch (Throwable e) {
+                log.info("getData request failed for dialect, " + dialect, e);
                 throw new DataRetrievalException(e);
             }
         } else {
             String message = "Failed to instantiate Data Locator for dialect, " + dialect;
             log.info(message);
             throw new DataRetrievalException(message);
-            }
-        return data; 
+        }
+        return data;
     }
-    
+
     /*
-     * For AxisService use only!
-     */    
-    public void loadServiceData(){
+    * For AxisService use only!
+    */
+    public void loadServiceData() {
         DataRetrievalUtil util = DataRetrievalUtil.getInstance();
-        
-        OMElement serviceData=null;
-        String file =  "META-INF/" + DRConstants.SERVICE_DATA.FILE_NAME;
+
+        OMElement serviceData = null;
+        String file = "META-INF/" + DRConstants.SERVICE_DATA.FILE_NAME;
         try {
-            serviceData = util.buildOM(axisService.getClassLoader(), "META-INF/" + DRConstants.SERVICE_DATA.FILE_NAME);
+            serviceData = util.buildOM(axisService.getClassLoader(),
+                                       "META-INF/" + DRConstants.SERVICE_DATA.FILE_NAME);
         } catch (DataRetrievalException e) {
             // It is not required to define ServiceData for a Service, just log a warning message
-        
+
             String message = "Check loading failure for file, " + file;
             log.debug(message + ".Message = " + e.getMessage());
             log.debug(message, e);
@@ -109,10 +110,10 @@
             cachingServiceData(serviceData);
         }
     }
-    
+
     /*
-     * caching ServiceData for Axis2 Data Locators
-     */
+    * caching ServiceData for Axis2 Data Locators
+    */
     private void cachingServiceData(OMElement e) {
         Iterator i = e.getChildrenWithName(new QName(
                 DRConstants.SERVICE_DATA.DATA));
@@ -127,25 +128,25 @@
             }
             dataMap.put(saveKey, data);
 
-            
+
         }
 
     }
-    
+
     /*
-     * Return ServiceData for specified dialect
-     */
-    private ArrayList getDataList(String dialect){
+    * Return ServiceData for specified dialect
+    */
+    private ArrayList getDataList(String dialect) {
         ArrayList dataList = new ArrayList();
         Iterator keys = dataMap.keySet().iterator();
-    
-        while (keys.hasNext()){
-            String keyStr = (String)keys.next();
+
+        while (keys.hasNext()) {
+            String keyStr = (String) keys.next();
             // get all Data element that matching the dialect
-            if (keyStr.indexOf(dialect) == 0){
+            if (keyStr.indexOf(dialect) == 0) {
                 dataList.add(dataMap.get(keyStr));
             }
         }
         return dataList;
-    }    
+    }
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/dataretrieval/BaseAxisDataLocator.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/dataretrieval/BaseAxisDataLocator.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/dataretrieval/BaseAxisDataLocator.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/dataretrieval/BaseAxisDataLocator.java Sun Mar  4 10:16:54 2007
@@ -24,26 +24,26 @@
 
 /**
  * BaseAxisDataLocator implements common code and serves as a base class
- * for the supported default Axis2 dialect data locators.  
+ * for the supported default Axis2 dialect data locators.
  */
 
-public abstract class BaseAxisDataLocator  {
+public abstract class BaseAxisDataLocator {
     private static final Log log = LogFactory.getLog(BaseAxisDataLocator.class);
 
     protected ServiceData[] dataList = null;
-    private OutputForm outputform= OutputForm.INLINE_FORM;
-    
+    private OutputForm outputform = OutputForm.INLINE_FORM;
+
     /**
      * The default Axis2 Data locator getData API
-     *   Checks data information configured in ServiceData.xml for the supported
-     *   output forms: inline, url, EndpointReference.
+     * Checks data information configured in ServiceData.xml for the supported
+     * output forms: inline, url, EndpointReference.
      * <p/>
      * Note: Subclass that has its implementation of outInlineForm, outputLocationForm,
-     *       and outputReferenceForm logic must implement the getData API.
+     * and outputReferenceForm logic must implement the getData API.
      */
-    
+
     public Data[] getData(DataRetrievalRequest request,
-            MessageContext msgContext) throws DataRetrievalException {
+                          MessageContext msgContext) throws DataRetrievalException {
         log.trace("Default Base DataLocator getData starts");
 
         OutputForm outputform = (OutputForm) request.getOutputForm();
@@ -53,27 +53,29 @@
         }
 
         Data[] output = null;
-                
+
         String outputFormString = outputform.getType();
-     
+
         if (outputform == OutputForm.INLINE_FORM) {
             output = outputInlineForm(msgContext, dataList);
         } else if (outputform == OutputForm.LOCATION_FORM) {
             output = outputLocationForm(dataList);
-            
+
         } else if (outputform == OutputForm.REFERENCE_FORM) {
             output = outputReferenceForm(msgContext, dataList);
-                    
+
         } else {
             output = outputInlineForm(msgContext, dataList);
-            
+
         }
-    
+
         if (output == null) {
-                log.info("Null data return! Data Locator does not know how to handle request for dialect= " + (String) request.getDialect()
-                    + " in the form of " + outputFormString);
+            log.info(
+                    "Null data return! Data Locator does not know how to handle request for dialect= " +
+                            (String) request.getDialect()
+                            + " in the form of " + outputFormString);
         }
-        
+
 
         log.trace("Default Base DataLocator getData ends");
 
@@ -84,7 +86,7 @@
      * WSDL or a policy document
      */
     protected Data[] outputInlineForm(MessageContext msgContext,
-            ServiceData[] serviceData) throws DataRetrievalException {
+                                      ServiceData[] serviceData) throws DataRetrievalException {
         OMElement metaElement = null;
         ArrayList result = new ArrayList();
         if (serviceData != null) {
@@ -98,13 +100,13 @@
 
             }
 
-    
+
         }
         return (Data[]) result.toArray(new Data[0]);
 
     }
 
-                                            
+
     protected Data[] outputLocationForm(ServiceData[] serviceData)
             throws DataRetrievalException {
 
@@ -115,14 +117,14 @@
                 String urlValue = serviceData[i].getURL();
                 if (urlValue != null) {
                     result.add(new Data(urlValue, serviceData[i].getIdentifier()));
+                }
             }
         }
-        }
         return (Data[]) result.toArray(new Data[0]);
     }
 
     protected Data[] outputReferenceForm(MessageContext msgContext,
-            ServiceData[] serviceData) throws DataRetrievalException {
+                                         ServiceData[] serviceData) throws DataRetrievalException {
         OMElement epr = null;
         ArrayList result = new ArrayList();
         if (serviceData != null) {
@@ -131,19 +133,19 @@
                 epr = serviceData[i].getEndpointReference();
                 if (epr != null) {
                     result.add(new Data((epr), serviceData[i].getIdentifier()));
+                }
             }
         }
-        }
         return (Data[]) result.toArray(new Data[0]);
     }
-    
+
 
     protected void setServiceData(ServiceData[] inServiceData) {
         this.dataList = inServiceData;
     }
 
-            
-    protected OutputForm getOutputForm(){
+
+    protected OutputForm getOutputForm() {
         return outputform;
     }
 



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