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 na...@apache.org on 2006/03/13 09:11:06 UTC

svn commit: r385453 [1/4] - in /webservices/axis2/trunk/c: include/ modules/xml/om/ modules/xml/soap/ test/unit/xml/om/ test/xml/om/ test/xml/soap/

Author: nandika
Date: Mon Mar 13 00:11:01 2006
New Revision: 385453

URL: http://svn.apache.org/viewcvs?rev=385453&view=rev
Log:
code reviewed and error handling improved , internal functions moved to internal headers 

Added:
    webservices/axis2/trunk/c/modules/xml/om/axis2_om_node_internal.h
    webservices/axis2/trunk/c/modules/xml/om/axis2_om_stax_builder_internal.h
    webservices/axis2/trunk/c/modules/xml/soap/axis2_soap11_builder_helper.h
    webservices/axis2/trunk/c/modules/xml/soap/axis2_soap12_builder_helper.h
Removed:
    webservices/axis2/trunk/c/include/axis2_soap11_builder_helper.h
    webservices/axis2/trunk/c/include/axis2_soap12_builder_helper.h
Modified:
    webservices/axis2/trunk/c/include/axis2_om_node.h
    webservices/axis2/trunk/c/include/axis2_om_stax_builder.h
    webservices/axis2/trunk/c/include/axis2_soap_builder.h
    webservices/axis2/trunk/c/include/axis2_soap_envelope.h
    webservices/axis2/trunk/c/include/axis2_soap_fault.h
    webservices/axis2/trunk/c/include/axis2_soap_fault_code.h
    webservices/axis2/trunk/c/include/axis2_soap_fault_detail.h
    webservices/axis2/trunk/c/include/axis2_soap_fault_node.h
    webservices/axis2/trunk/c/include/axis2_soap_fault_reason.h
    webservices/axis2/trunk/c/include/axis2_soap_fault_role.h
    webservices/axis2/trunk/c/include/axis2_soap_fault_sub_code.h
    webservices/axis2/trunk/c/include/axis2_soap_fault_text.h
    webservices/axis2/trunk/c/include/axis2_soap_fault_value.h
    webservices/axis2/trunk/c/include/axis2_soap_header.h
    webservices/axis2/trunk/c/include/axis2_soap_header_block.h
    webservices/axis2/trunk/c/modules/xml/om/Makefile.am
    webservices/axis2/trunk/c/modules/xml/om/om_children_qname_iterator.c
    webservices/axis2/trunk/c/modules/xml/om/om_comment.c
    webservices/axis2/trunk/c/modules/xml/om/om_doctype.c
    webservices/axis2/trunk/c/modules/xml/om/om_document.c
    webservices/axis2/trunk/c/modules/xml/om/om_element.c
    webservices/axis2/trunk/c/modules/xml/om/om_node.c
    webservices/axis2/trunk/c/modules/xml/om/om_processing_instruction.c
    webservices/axis2/trunk/c/modules/xml/om/om_stax_builder.c
    webservices/axis2/trunk/c/modules/xml/om/om_text.c
    webservices/axis2/trunk/c/modules/xml/soap/Makefile.am
    webservices/axis2/trunk/c/modules/xml/soap/soap11_builder_helper.c
    webservices/axis2/trunk/c/modules/xml/soap/soap12_builder_helper.c
    webservices/axis2/trunk/c/modules/xml/soap/soap_body.c
    webservices/axis2/trunk/c/modules/xml/soap/soap_builder.c
    webservices/axis2/trunk/c/modules/xml/soap/soap_envelope.c
    webservices/axis2/trunk/c/modules/xml/soap/soap_fault.c
    webservices/axis2/trunk/c/modules/xml/soap/soap_fault_code.c
    webservices/axis2/trunk/c/modules/xml/soap/soap_fault_detail.c
    webservices/axis2/trunk/c/modules/xml/soap/soap_fault_node.c
    webservices/axis2/trunk/c/modules/xml/soap/soap_fault_reason.c
    webservices/axis2/trunk/c/modules/xml/soap/soap_fault_role.c
    webservices/axis2/trunk/c/modules/xml/soap/soap_fault_sub_code.c
    webservices/axis2/trunk/c/modules/xml/soap/soap_fault_text.c
    webservices/axis2/trunk/c/modules/xml/soap/soap_fault_value.c
    webservices/axis2/trunk/c/modules/xml/soap/soap_header.c
    webservices/axis2/trunk/c/modules/xml/soap/soap_header_block.c
    webservices/axis2/trunk/c/test/unit/xml/om/Makefile.am
    webservices/axis2/trunk/c/test/unit/xml/om/om_node_test.c
    webservices/axis2/trunk/c/test/xml/om/test_om.c
    webservices/axis2/trunk/c/test/xml/soap/test_soap.c

Modified: webservices/axis2/trunk/c/include/axis2_om_node.h
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/c/include/axis2_om_node.h?rev=385453&r1=385452&r2=385453&view=diff
==============================================================================
--- webservices/axis2/trunk/c/include/axis2_om_node.h (original)
+++ webservices/axis2/trunk/c/include/axis2_om_node.h Mon Mar 13 00:11:01 2006
@@ -134,19 +134,6 @@
                                         axis2_om_node_t  * node_to_insert);
 
     /**
-    * Sets a parent node to a given node, if a parent already exist for this node
-    * then it is detached before seting the parent
-    * @param om_node child node to whom a parent to be added. , cannot be NULL.
-    * @param env Environment. MUST NOT be NULL, .
-    * @param parent_node the node that will be set as parent. , cannot be NULL.
-    * @return satus of the op. AXIS2_SUCCESS on success else AXIS2_FAILURE
-    */
-    axis2_status_t (AXIS2_CALL *set_parent) (axis2_om_node_t  *om_node,
-                                             axis2_env_t **env,
-                                             axis2_om_node_t  *parent_node);
-
-    
-    /**
     * Serializes the given node. This op makes the node go
     * through its children and  serialize them in order.
     * @param om_node node to be serialized.  cannot be NULL.
@@ -176,7 +163,6 @@
     * @returns pointer to first child node , NULL is returned on error with 
     *                     error code set in environments error
     */
-
     axis2_om_node_t * (AXIS2_CALL *get_first_child)
                                             (axis2_om_node_t  *om_node,
                                             axis2_env_t **env);
@@ -186,7 +172,6 @@
     * @param env environment, MUST NOT be NULL
     * @return pointer to last child of this node , return NULL on error.
     */                                                   
-                
     axis2_om_node_t * (AXIS2_CALL *get_last_child)
                                         (axis2_om_node_t  *om_node,
                                             axis2_env_t **env);
@@ -197,7 +182,6 @@
     * @returns a pointer to previous sibling , NULL if a previous sibling does not exits
     *                (happens when this node is the first child of a node )
     */                                                            
-
     axis2_om_node_t * (AXIS2_CALL *get_previous_sibling)
                                         (axis2_om_node_t  *om_node,
                                          axis2_env_t **env);
@@ -207,8 +191,6 @@
     * @param env environment, MUST NOT be NULL.
     * @return next sibling of this node.
     */ 
-    
-    
     axis2_om_node_t * (AXIS2_CALL *get_next_sibling)
                                         (axis2_om_node_t  *om_node,
                                          axis2_env_t **env);
@@ -220,7 +202,6 @@
     * @param env environment
     * @return node type
     */
-    
     axis2_om_types_t (AXIS2_CALL *get_node_type)
                                         (axis2_om_node_t  *om_node,
                                          axis2_env_t **env);
@@ -245,83 +226,6 @@
     axis2_bool_t (AXIS2_CALL *get_build_status)
                                         (axis2_om_node_t  *om_node,
                                             axis2_env_t **env); 
-    /**
-    *   sets a node as first child of om_node
-    * @param om_node om_node
-    * @param env environment, MUST NOT be NULL.
-    * @param first_child child to be set as first child
-    */                                                                        
-
-    axis2_status_t (AXIS2_CALL *set_first_child)
-                                        (axis2_om_node_t  *om_node,
-                                        axis2_env_t **env,
-                                        axis2_om_node_t  *first_child);
-   /**
-    * set next sibling
-    * @param om_node 
-    * @param env environment, MUST NOT be NULL.
-    * @param last_sibling 
-    * @return status of the op, AXIS2_SUCCESS on success,
-    *                   AXIS2_FAILURE on error
-    */                                                  
-    axis2_status_t (AXIS2_CALL *set_next_sibling)
-                                        (axis2_om_node_t  *om_node,
-                                            axis2_env_t **env,
-                                            axis2_om_node_t  *last_sibling);
-    /**
-    * set previous sibling
-    * @param om_node 
-    * @param env environment, MUST NOT be NULL.
-    * @param prev_sibling 
-    * @return status of the op, AXIS2_SUCCESS on success
-    *               AXIS2_FAILURE on error
-    */
-    
-    axis2_status_t (AXIS2_CALL *set_previous_sibling)
-                                        (axis2_om_node_t  *om_node,
-                                            axis2_env_t **env,
-                                            axis2_om_node_t  *prev_sibling);
-    /**
-    *   set node type
-    * @param om_node    
-    * @param env environment, MUST NOT be NULL.
-    * @param type type of the node
-    * @return status code of the op AXIS2_SUCCESS on success,
-    *                       AXIS2_FAILURE on error
-    */
-    
-    axis2_status_t (AXIS2_CALL *set_node_type)
-                                        (axis2_om_node_t  *om_node,
-                                            axis2_env_t **env,
-                                            axis2_om_types_t type);
-    /**
-    * set data element
-    * @param om_node  node struct  
-    * @param env environment, MUST NOT be NULL.
-    * @param data_element 
-    * @return status code of the op AXIS2_SUCCESS on success,
-    *                       AXIS2_FAILURE on error
-    */
-    axis2_status_t (AXIS2_CALL *set_data_element)(axis2_om_node_t  *om_node,
-                                                  axis2_env_t **env,
-                                                  void* data_element);
-    /**
-    * set build status, if the node if completety build build status is
-    * set to AXIS2_TRUE , otherwise AXIS2_FALSE  
-    * @param om_node 
-    * @param env environment, MUST NOT be NULL.
-    * @param done                   
-    */                          
-    axis2_status_t (AXIS2_CALL *set_build_status)(axis2_om_node_t  *om_node,
-                                                  axis2_env_t **env,
-                                                  axis2_bool_t done);
-   /**
-    * This functions is only to be used by builder
-    * do not use this function
-    */                                             
-   axis2_status_t (AXIS2_CALL *set_document)(axis2_om_node_t *om_node,
-                                              axis2_env_t **env,
-                                             struct axis2_om_document *om_doc);
    /**
     * returns the associated document,
     * only valid if built using builder and for a node of type 
@@ -330,7 +234,7 @@
     * @param om_node 
     * @param env environment, MUST NOT be NULL.
     */   
-struct axis2_om_document* (AXIS2_CALL *get_document)
+    struct axis2_om_document* (AXIS2_CALL *get_document)
                                     (axis2_om_node_t *om_node,
                                      axis2_env_t **env);
    /**
@@ -345,10 +249,6 @@
     axis2_om_node_t* (AXIS2_CALL *build_next)(axis2_om_node_t *om_node,
                                               axis2_env_t **env);
                                               
-    axis2_status_t (AXIS2_CALL *set_builder)(axis2_om_node_t *om_node,
-                                             axis2_env_t **env,
-                                             struct axis2_om_stax_builder *builder);                                              
-    
                                                                         
 } axis2_om_node_ops_t;
 
@@ -369,28 +269,22 @@
     * @param env Environment. MUST NOT be NULL, .
     * @return a pointer to newly created node struct. NULL on error. 
     */
-AXIS2_DECLARE(axis2_om_node_t *) axis2_om_node_create (axis2_env_t **env);
+AXIS2_DECLARE(axis2_om_node_t *) 
+axis2_om_node_create (axis2_env_t **env);
 
 /** frees given node */
 #define AXIS2_OM_NODE_FREE_TREE(om_node,env) ((om_node)->ops->free(om_node,env))
 /** adds given child to the given parent */
-
 #define AXIS2_OM_NODE_ADD_CHILD(om_node, env, child) \
         ((om_node)->ops->add_child(om_node, env, child))
 /** detaches the given node from its parent */
-
 #define AXIS2_OM_NODE_DETACH(om_node,env) ((om_node)->ops->detach(om_node,env))
 /** inserts a sibling after the given node */
-
 #define AXIS2_OM_NODE_INSERT_SIBLING_AFTER(om_node,env,node_to_insert) \
         ((om_node)->ops->insert_sibling_after(om_node,env,node_to_insert))
 /** inserts a sibling before the given node */
 #define AXIS2_OM_NODE_INSERT_SIBLING_BEFORE(om_node,env,node_to_insert) \
         ((om_node)->ops->insert_sibling_before(om_node,env,node_to_insert))
-   
-/** sets the parent of the given node */
-#define AXIS2_OM_NODE_SET_PARENT(om_node,env,parent_node) \
-        ((om_node)->ops->set_parent(om_node,env,parent_node))
 /** serialize an om_node and all its children */
 #define AXIS2_OM_NODE_SERIALIZE(om_node,env, om_output) \
         ((om_node)->ops->serialize(om_node,env,om_output))
@@ -415,32 +309,9 @@
 /** get data element of this node can be om_element om_text etc */
 #define AXIS2_OM_NODE_GET_DATA_ELEMENT(om_node,env) \
         ((om_node)->ops->get_data_element(om_node,env))
-        
 /** node type one of om_node_types */
 #define AXIS2_OM_NODE_GET_NODE_TYPE(om_node,env) \
         ((om_node)->ops->get_node_type(om_node,env))       
-
-/** set first child */
-#define AXIS2_OM_NODE_SET_FIRST_CHILD(om_node,env,first_child)\
-        ((om_node)->ops->set_first_child(om_node,env,first_child))
-/** set previous sibling */
-#define AXIS2_OM_NODE_SET_PREVIOUS_SIBLING(om_node,env,prev_sibling) \
-        ((om_node)->ops->set_previous_sibling(om_node,env,prev_sibling))
-/** set next sibling */  
-#define AXIS2_OM_NODE_SET_NEXT_SIBLING(om_node,env,next_sibling) \
-        ((om_node)->ops->set_next_sibling(om_node,env,next_sibling))
-/** set build status */
-#define AXIS2_OM_NODE_SET_BUILD_STATUS(om_node,env,done) \
-        ((om_node)->ops->set_build_status(om_node,env,done))
-/** set data element */
-#define AXIS2_OM_NODE_SET_DATA_ELEMENT(om_node,env,data_element) \
-        ((om_node)->ops->set_data_element(om_node,env,data_element))
-/** set node type */   
-#define AXIS2_OM_NODE_SET_NODE_TYPE(om_node,env,node_type) \
-        ((om_node)->ops->set_node_type(om_node,env,node_type))  
-/** set document */
-#define AXIS2_OM_NODE_SET_DOCUMENT(om_node, env, om_doc) \
-        ((om_node)->ops->set_document(om_node, env, om_doc))
 /** get document */        
 #define AXIS2_OM_NODE_GET_DOCUMENT(om_node, env) \
         ((om_node)->ops->get_document(om_node, env))
@@ -448,9 +319,6 @@
 #define AXIS2_OM_NODE_BUILD_NEXT(om_node, env) \
         ((om_node)->ops->build_next(om_node, env)) 
         
-#define AXIS2_OM_NODE_SET_BUILDER(om_node, env, builder) \
-        ((om_node)->ops->set_builder(om_node, env, builder))               
-
 /** @} */
 
 #ifdef __cplusplus

Modified: webservices/axis2/trunk/c/include/axis2_om_stax_builder.h
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/c/include/axis2_om_stax_builder.h?rev=385453&r1=385452&r2=385453&view=diff
==============================================================================
--- webservices/axis2/trunk/c/include/axis2_om_stax_builder.h (original)
+++ webservices/axis2/trunk/c/include/axis2_om_stax_builder.h Mon Mar 13 00:11:01 2006
@@ -36,11 +36,6 @@
     struct axis2_om_stax_builder;
     struct axis2_om_stax_builder_ops;
 
-    typedef enum builder_types
-    {
-        AXIS2_OM_STAX_BUILDER = 0,
-        AXIS2_SOAP_BUILDER
-    } builder_types_t;
 /**
  * @defgroup axis2_om_stax_builder OM Stax Builder
  * @ingroup axis2_om 
@@ -107,33 +102,14 @@
                                                    axis2_env_t **env,
                                                    axis2_om_document_t *document); 
         /**
-         *  get the builder's current event
-         *  @return returns one of axis2_xml_reader_event_types
-         *  returns -1 of the next method on builder has not been called yet
-         *
-         */
-        int (AXIS2_CALL *get_current_event)(struct axis2_om_stax_builder *builder,
-                                            axis2_env_t **env);
-                                            
-        axis2_om_node_t* (AXIS2_CALL *get_last_node)
-                                            (struct axis2_om_stax_builder* builder,
-                                             axis2_env_t **env);
+         * builder is finished building om structure
+         */        
                                              
         axis2_bool_t (AXIS2_CALL *is_complete)(struct axis2_om_stax_builder* builder,
                                                axis2_env_t **env);
-                                                                   
-        axis2_status_t (AXIS2_CALL *set_last_node)
-                                              (struct axis2_om_stax_builder* builder,
-                                               axis2_env_t **env,
-                                               axis2_om_node_t *om_node);                                                                                            
-        int (AXIS2_CALL *get_element_level)(struct axis2_om_stax_builder* builder,
-                                            axis2_env_t **env); 
-                                            
-        axis2_status_t (AXIS2_CALL *set_element_level)
-                                            (struct axis2_om_stax_builder* builder,
-                                             axis2_env_t **env,
-                                             int element_level); 
-                                             
+        /**
+         *  moves the reader to next event        
+         */                                                
         int (AXIS2_CALL *next_with_token)(struct axis2_om_stax_builder *builder,
                                           axis2_env_t **env);                                                                                                                                                                                                                                                 
                                                         
@@ -175,25 +151,10 @@
 /** get the document associated with the builder */  
 #define AXIS2_OM_STAX_BUILDER_GET_DOCUMENT(builder,env) \
         ((builder)->ops->get_document(builder,env))
-/** returns the xml readers current event */
-#define AXIS2_OM_STAX_BUILDER_GET_CURRENT_EVENT(builder, env) \
-        ((builder)->ops->get_current_event(builder, env))
-        
-#define AXIS2_OM_STAX_BUILDER_GET_LAST_NODE(builder, env) \
-        ((builder)->ops->get_last_node(builder, env)) 
-        
+/** builder is finished building */        
 #define AXIS2_OM_STAX_BUILDER_IS_COMPLETE(builder, env) \
         ((builder)->ops->is_complete(builder, env))                       
-	
-#define AXIS2_OM_STAX_BUILDER_SET_LAST_NODE(builder, env, node) \
-        ((builder)->ops->set_last_node(builder, env, node))
-        
-#define AXIS2_OM_STAX_BUILDER_GET_ELEMENT_LEVEL(builder, env) \
-        ((builder)->ops->get_element_level(builder, env))
-        
-#define AXIS2_OM_STAX_BUILDER_SET_ELEMENT_LEVEL(builder, env, element_level) \
-        ((builder)->ops->set_element_level(builder, env, element_level)) 
-        
+/** moves the builder to next event */	
 #define AXIS2_OM_STAX_BUILDER_NEXT_WITH_TOKEN(builder, env) \
         ((builder)->ops->next_with_token(builder, env))                    
 

Modified: webservices/axis2/trunk/c/include/axis2_soap_builder.h
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/c/include/axis2_soap_builder.h?rev=385453&r1=385452&r2=385453&view=diff
==============================================================================
--- webservices/axis2/trunk/c/include/axis2_soap_builder.h (original)
+++ webservices/axis2/trunk/c/include/axis2_soap_builder.h Mon Mar 13 00:11:01 2006
@@ -84,11 +84,6 @@
         int (AXIS2_CALL *get_soap_version)(axis2_soap_builder_t *builder,
                                            axis2_env_t **env);
                                            
-        axis2_status_t (AXIS2_CALL *set_element_level)
-                                          (axis2_soap_builder_t *builder,
-                                           axis2_env_t **env,
-                                           int ele_level);
-
         axis2_status_t (AXIS2_CALL *process_namespace_data)
                                           (axis2_soap_builder_t *builder,
                                            axis2_env_t **env,

Modified: webservices/axis2/trunk/c/include/axis2_soap_envelope.h
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/c/include/axis2_soap_envelope.h?rev=385453&r1=385452&r2=385453&view=diff
==============================================================================
--- webservices/axis2/trunk/c/include/axis2_soap_envelope.h (original)
+++ webservices/axis2/trunk/c/include/axis2_soap_envelope.h Mon Mar 13 00:11:01 2006
@@ -125,7 +125,7 @@
                                            axis2_env_t **env);
                    
         /**
-         * set soap version
+         * set soap version, This is internal function do not use outside of soap
          */         
         axis2_status_t (AXIS2_CALL *set_soap_version)
                                           (axis2_soap_envelope_t *envelope,
@@ -141,6 +141,7 @@
         /** 
          * set soap header. This is just a pointer assignment intended to be used
          * by soap builder . Does not adjust the om tree accordingly
+         * do not use outsize of soap
          */         
         axis2_status_t (AXIS2_CALL *set_header)(axis2_soap_envelope_t *envelope,
                                                 axis2_env_t **env, 
@@ -157,6 +158,7 @@
         /** 
          * Associate a soap builder with this soap envelope
          * This function is intended to be used by builder
+         * do not use outside of soap
          */                                                
 
         axis2_status_t (AXIS2_CALL *set_builder)(axis2_soap_envelope_t *envelope,
@@ -182,6 +184,7 @@
 AXIS2_DECLARE(axis2_soap_envelope_t*)
 axis2_soap_envelope_create(axis2_env_t **env, axis2_om_namespace_t *ns);
 
+
 AXIS2_DECLARE(axis2_soap_envelope_t*)
 axis2_soap_envelope_create_null(axis2_env_t **env);
 
@@ -220,10 +223,10 @@
         
 #define AXIS2_SOAP_ENVELOPE_GET_SOAP_VERSION(envelope, env) \
         ((envelope)->ops->get_soap_version(envelope, env))
-        
+
 #define AXIS2_SOAP_ENVELOPE_SET_SOAP_VERSION(envelope, env, soap_version) \
         ((envelope)->ops->set_soap_version(envelope, env, soap_version))
-        
+
 #define AXIS2_SOAP_ENVELOPE_SET_BODY(envelope, env, body) \
         ((envelope)->ops->set_body(envelope, env, body))
         

Modified: webservices/axis2/trunk/c/include/axis2_soap_fault.h
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/c/include/axis2_soap_fault.h?rev=385453&r1=385452&r2=385453&view=diff
==============================================================================
--- webservices/axis2/trunk/c/include/axis2_soap_fault.h (original)
+++ webservices/axis2/trunk/c/include/axis2_soap_fault.h Mon Mar 13 00:11:01 2006
@@ -148,14 +148,6 @@
                                              (axis2_soap_fault_t *fault,
                                               axis2_env_t **env);  
                                                      
-        axis2_status_t (AXIS2_CALL *set_soap_version)
-                                             (axis2_soap_fault_t *fault,
-                                              axis2_env_t **env,
-                                              int soap_version);
-                                           
-        int (AXIS2_CALL *get_soap_version)(axis2_soap_fault_t *fault,
-                                           axis2_env_t **env); 
-                                           
         axis2_status_t (AXIS2_CALL *set_builder)(axis2_soap_fault_t *fault,
                                             axis2_env_t **env,
                                             struct axis2_soap_builder *builder);                                                                                                                                                                                                                                                                                                     
@@ -241,11 +233,6 @@
 #define AXIS2_SOAP_FAULT_GET_BASE_NODE(fault, env) \
         ((fault)->ops->get_base_node(fault, env)) 
         
-#define AXIS2_SOAP_FAULT_GET_SOAP_VERSION(fault, env) \
-        ((fault)->ops->get_soap_version(fault, env))
-        
-#define AXIS2_SOAP_FAULT_SET_SOAP_VERSION(fault, env, soap_version) \
-        ((fault)->ops->set_soap_version(fault, env, soap_version))
         
 #define AXIS2_SOAP_FAULT_GET_EXCEPTION(fault, env) \
         ((fault)->ops->get_exception(fault, env))

Modified: webservices/axis2/trunk/c/include/axis2_soap_fault_code.h
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/c/include/axis2_soap_fault_code.h?rev=385453&r1=385452&r2=385453&view=diff
==============================================================================
--- webservices/axis2/trunk/c/include/axis2_soap_fault_code.h (original)
+++ webservices/axis2/trunk/c/include/axis2_soap_fault_code.h Mon Mar 13 00:11:01 2006
@@ -55,19 +55,9 @@
         * @return satus of the op. AXIS2_SUCCESS on success 
         *         else AXIS2_FAILURE
         */
-
         axis2_status_t (AXIS2_CALL *free_fn)
                                     (axis2_soap_fault_code_t *fault_code,
                                      axis2_env_t **env);
-        axis2_status_t (AXIS2_CALL *set_value)
-                                    (axis2_soap_fault_code_t *fault_code,
-                                     axis2_env_t **env,
-                                     struct axis2_soap_fault_value *fault_val);
-
-        axis2_status_t (AXIS2_CALL *set_sub_code)
-                                    (axis2_soap_fault_code_t *fault_code,
-                                     axis2_env_t **env,
-                                     struct axis2_soap_fault_sub_code *fault_subcode);                                                                         
         
         struct axis2_soap_fault_sub_code* (AXIS2_CALL *get_sub_code)                                         
                                     (axis2_soap_fault_code_t *fault_code,
@@ -77,30 +67,31 @@
                                     (axis2_soap_fault_code_t *fault_code,
                                      axis2_env_t **env);
                                      
-        axis2_status_t (AXIS2_CALL *set_base_node)
-                                    (axis2_soap_fault_code_t *fault_code,
-                                     axis2_env_t **env,
-                                     axis2_om_node_t *node);
-    
         axis2_om_node_t* (AXIS2_CALL *get_base_node)
                                     (axis2_soap_fault_code_t *fault_code,
                                      axis2_env_t **env);
                                  
-        int (AXIS2_CALL *get_soap_version)                                 
-                                    (axis2_soap_fault_code_t *fault_code,
-                                     axis2_env_t **env);
-                                                                                                                 
-        axis2_status_t (AXIS2_CALL *set_soap_version)
+        axis2_status_t (AXIS2_CALL *set_value)
+                            (axis2_soap_fault_code_t *fault_code,
+                             axis2_env_t **env,
+                             struct axis2_soap_fault_value *fault_val);
+
+        axis2_status_t (AXIS2_CALL *set_sub_code)
                                     (axis2_soap_fault_code_t *fault_code,
                                      axis2_env_t **env,
-                                     int soap_version); 
-                                     
+                                     struct axis2_soap_fault_sub_code *fault_subcode);                                                                         
+
         axis2_status_t (AXIS2_CALL *set_builder)
                                     (axis2_soap_fault_code_t *fault_code,
                                      axis2_env_t **env,
                                      struct axis2_soap_builder *builder);
     
-    };      
+        axis2_status_t (AXIS2_CALL *set_base_node)
+                                    (axis2_soap_fault_code_t *fault_code,
+                                     axis2_env_t **env,
+                                     axis2_om_node_t *node);
+
+};      
 
   /**
     * \brief soap_fault_code struct
@@ -123,17 +114,7 @@
     
 AXIS2_DECLARE(axis2_soap_fault_code_t *)
 axis2_soap_fault_code_create_with_parent(axis2_env_t **env,
-                            axis2_soap_fault_t *fault,
-                            axis2_bool_t extract_ns_from_parent);
-                            
-
-AXIS2_DECLARE(axis2_soap_fault_code_t *)
-axis2_soap11_fault_code_create_with_parent(axis2_env_t **env,
-                             axis2_soap_fault_t *fault);
-
-AXIS2_DECLARE(axis2_soap_fault_code_t *)
-axis2_soap12_fault_code_create_with_parent(axis2_env_t **env,
-                             axis2_soap_fault_t *fault);
+                            axis2_soap_fault_t *fault);
 
 /******************** Macros **************************************************/
     
@@ -142,33 +123,28 @@
 #define AXIS2_SOAP_FAULT_CODE_FREE(fault_code , env) \
         ((fault_code)->ops->free_fn(fault_code, env))
 
-#define AXIS2_SOAP_FAULT_CODE_SET_SUB_CODE(fault_code , env, subcode) \
-        ((fault_code)->ops->set_sub_code(fault_code, env, subcode))
-        
 #define AXIS2_SOAP_FAULT_CODE_GET_SUB_CODE(fault_code , env) \
         ((fault_code)->ops->get_sub_code(fault_code, env))        
 
-#define AXIS2_SOAP_FAULT_CODE_SET_VALUE(fault_code , env, value) \
-        ((fault_code)->ops->set_value(fault_code, env, value))
-
 #define AXIS2_SOAP_FAULT_CODE_GET_VALUE(fault_code , env) \
         ((fault_code)->ops->get_node(fault_code, env)) 
         
 #define AXIS2_SOAP_FAULT_CODE_GET_BASE_NODE(fault_code, env) \
         ((fault_code)->ops->get_base_node(fault_code, env))         
 
+/** internal functions */
+#define AXIS2_SOAP_FAULT_CODE_SET_SUB_CODE(fault_code , env, subcode) \
+        ((fault_code)->ops->set_sub_code(fault_code, env, subcode))
+
 #define AXIS2_SOAP_FAULT_CODE_SET_BASE_NODE(fault_code, env, node) \
         ((fault_code)->ops->set_base_node(fault_code, env, node))  
-
-#define AXIS2_SOAP_FAULT_CODE_SET_SOAP_VERSION(fault_code, env, version) \
-        ((fault_code)->ops->set_soap_version(fault_code, env, version))
-        
-#define AXIS2_SOAP_FAULT_CODE_GET_SOAP_VERSION(fault_code, env) \
-        ((fault_code)->ops->get_soap_version(fault_code, env))        
         
 #define AXIS2_SOAP_FAULT_CODE_SET_BUILDER(fault_code, env, builder) \
         ((fault_code)->ops->set_builder(fault_code, env, builder))
                 
+#define AXIS2_SOAP_FAULT_CODE_SET_VALUE(fault_code , env, value) \
+        ((fault_code)->ops->set_value(fault_code, env, value))
+
 /** @} */
 
 #ifdef __cplusplus

Modified: webservices/axis2/trunk/c/include/axis2_soap_fault_detail.h
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/c/include/axis2_soap_fault_detail.h?rev=385453&r1=385452&r2=385453&view=diff
==============================================================================
--- webservices/axis2/trunk/c/include/axis2_soap_fault_detail.h (original)
+++ webservices/axis2/trunk/c/include/axis2_soap_fault_detail.h Mon Mar 13 00:11:01 2006
@@ -76,15 +76,6 @@
                                 (axis2_soap_fault_detail_t *fault_code,
                                  axis2_env_t **env);
         
-        int (AXIS2_CALL *get_soap_version)
-                                (axis2_soap_fault_detail_t *fault_detail,
-                                 axis2_env_t **env);
-                                 
-        axis2_status_t (AXIS2_CALL *set_soap_version)
-                                (axis2_soap_fault_detail_t *fault_detail,
-                                 axis2_env_t **env,
-                                 int soap_version);                                  
-                                                                                                                
     };      
 
   /**
@@ -109,20 +100,10 @@
 AXIS2_DECLARE(axis2_soap_fault_detail_t *)
 axis2_soap_fault_detail_create_with_parent
                         (axis2_env_t **env,
-                         axis2_soap_fault_t *fault,
-                         axis2_bool_t extract_ns_from_parent);
+                         axis2_soap_fault_t *fault);
                          
-AXIS2_DECLARE(axis2_soap_fault_detail_t *)
-axis2_soap11_fault_detail_create(axis2_env_t **env,
-                               axis2_soap_fault_t *fault); 
-
-AXIS2_DECLARE(axis2_soap_fault_detail_t *)
-axis2_soap12_fault_detail_create(axis2_env_t **env,
-                               axis2_soap_fault_t *fault);                                                       
-
 /******************** Macros **************************************************/
     
-    
 /** free soap_fault_detail */
 #define AXIS2_SOAP_FAULT_DETAIL_FREE(fault_detail , env) \
         ((fault_detail)->ops->free_fn(fault_detail, env))
@@ -139,11 +120,6 @@
 #define AXIS2_SOAP_FAULT_DETAIL_SET_BASE_NODE(fault_detail, env, node) \
         ((fault_detail)->ops->set_base_node(fault_detail, env, node))
         
-#define AXIS2_SOAP_FAULT_DETAIL_GET_SOAP_VERSION(fault_detail, env) \
-        ((fault_detail)->ops->get_soap_version(fault_detail, env))
-        
-#define AXIS2_SOAP_FAULT_DETAIL_SET_SOAP_VERSION(fault_detail, env, version) \
-        ((fault_detail)->ops->set_soap_version(fault_detail, env, version))                  
 /** @} */
 
 #ifdef __cplusplus
@@ -151,5 +127,3 @@
 #endif
  
 #endif /* AXIS2_SOAP_FAULT_DETAIL_H */
-
-

Modified: webservices/axis2/trunk/c/include/axis2_soap_fault_node.h
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/c/include/axis2_soap_fault_node.h?rev=385453&r1=385452&r2=385453&view=diff
==============================================================================
--- webservices/axis2/trunk/c/include/axis2_soap_fault_node.h (original)
+++ webservices/axis2/trunk/c/include/axis2_soap_fault_node.h Mon Mar 13 00:11:01 2006
@@ -73,15 +73,6 @@
                                    (axis2_soap_fault_node_t *fault_node,
                                     axis2_env_t **env);
                                     
-        int (AXIS2_CALL *get_soap_version)
-                                   (axis2_soap_fault_node_t *fault_node,
-                                    axis2_env_t **env);
-                                 
-        axis2_status_t (AXIS2_CALL *set_soap_version)
-                                   (axis2_soap_fault_node_t *fault_node,
-                                    axis2_env_t **env,
-                                    int soap_version);                                     
-                                                                                                                
     };      
 
   /**
@@ -114,25 +105,19 @@
 #define AXIS2_SOAP_FAULT_NODE_FREE(fault_node , env) \
         ((fault_node)->ops->free_fn(fault_node, env))
 
-#define AXIS2_SOAP_FAULT_NODE_SET_VALUE(fault_node , env, uri) \
-        ((fault_node)->ops->set_value(fault_node, env, uri))
-
-        
 #define AXIS2_SOAP_FAULT_NODE_GET_VALUE(fault_node , env) \
         ((fault_node)->ops->get_node(fault_node, env)) 
         
 #define AXIS2_SOAP_FAULT_NODE_GET_BASE_NODE(fault_node, env) \
         ((fault_node)->ops->get_base_node(fault_node, env))         
 
+/** internal functons , do not use */
 #define AXIS2_SOAP_FAULT_NODE_SET_BASE_NODE(fault_node, env, node) \
         ((fault_node)->ops->set_base_node(fault_node, env, node))
         
-#define AXIS2_SOAP_FAULT_NODE_SET_SOAP_VERSION(fault_node, env, soap_version) \
-        ((fault_node)->ops->set_soap_version(fault_node, env, soap_version))
+#define AXIS2_SOAP_FAULT_NODE_SET_VALUE(fault_node , env, uri) \
+        ((fault_node)->ops->set_value(fault_node, env, uri))        
         
-#define AXIS2_SOAP_FAULT_NODE_GET_SOAP_VERSION(fault_node, env) \
-        ((fault_node)->ops->get_soap_version(fault_node, env))
-                        
 /** @} */
 
 #ifdef __cplusplus
@@ -140,5 +125,3 @@
 #endif
 
 #endif /* AXIS2_SOAP_FAULT_NODE_H */
-
-

Modified: webservices/axis2/trunk/c/include/axis2_soap_fault_reason.h
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/c/include/axis2_soap_fault_reason.h?rev=385453&r1=385452&r2=385453&view=diff
==============================================================================
--- webservices/axis2/trunk/c/include/axis2_soap_fault_reason.h (original)
+++ webservices/axis2/trunk/c/include/axis2_soap_fault_reason.h Mon Mar 13 00:11:01 2006
@@ -57,33 +57,25 @@
                                 (axis2_soap_fault_reason_t *fault_reason,
                                  axis2_env_t **env);
 
-        axis2_status_t (AXIS2_CALL *set_soap_fault_text)
-                                (axis2_soap_fault_reason_t *fault_reason,
-                                 axis2_env_t **env,
-                                 struct axis2_soap_fault_text *soap_text);
-                                     
         struct axis2_soap_fault_text* (AXIS2_CALL *get_soap_text)                                         
                                 (axis2_soap_fault_reason_t *fault_reason,
                                  axis2_env_t **env);
                                      
-        axis2_status_t (AXIS2_CALL *set_base_node)
-                                (axis2_soap_fault_reason_t *fault_reason,
-                                 axis2_env_t **env,
-                                 axis2_om_node_t *node);
-    
         axis2_om_node_t* (AXIS2_CALL *get_base_node)
                                 (axis2_soap_fault_reason_t *fault_reason,
                                  axis2_env_t **env);
                                  
-        int (AXIS2_CALL *get_soap_version)
+        /** internal functions , do not use */
+        axis2_status_t (AXIS2_CALL *set_base_node)
                                 (axis2_soap_fault_reason_t *fault_reason,
-                                 axis2_env_t **env);
-                                 
-        axis2_status_t (AXIS2_CALL *set_soap_version)
+                                 axis2_env_t **env,
+                                 axis2_om_node_t *node);
+    
+        axis2_status_t (AXIS2_CALL *set_soap_fault_text)
                                 (axis2_soap_fault_reason_t *fault_reason,
                                  axis2_env_t **env,
-                                 int soap_version);                                                                        
-                                                       
+                                 struct axis2_soap_fault_text *soap_text);      
+      
         axis2_status_t (AXIS2_CALL *set_builder)
                                 (axis2_soap_fault_reason_t *fault_reason,
                                  axis2_env_t **env,
@@ -110,24 +102,14 @@
     
 AXIS2_DECLARE(axis2_soap_fault_reason_t *)
 axis2_soap_fault_reason_create_with_parent(axis2_env_t **env,
-                            axis2_soap_fault_t *fault,
-                            axis2_bool_t extact_ns_from_parent);
-
-AXIS2_DECLARE(axis2_soap_fault_reason_t *)
-axis2_soap11_fault_reason_create_with_parent(axis2_env_t **env,
-                            axis2_soap_fault_t *fault);    
-                            
-AXIS2_DECLARE(axis2_soap_fault_reason_t *)
-axis2_soap12_fault_reason_create_with_parent(axis2_env_t **env,
                             axis2_soap_fault_t *fault);
+
 /******************** Macros **************************************************/
     
 /** free soap_fault_reason */
 #define AXIS2_SOAP_FAULT_REASON_FREE(fault_reason , env) \
         ((fault_reason)->ops->free_fn(fault_reason, env))
 
-#define AXIS2_SOAP_FAULT_REASON_SET_SOAP_FAULT_TEXT(fault_reason , env, soap_text) \
-        ((fault_reason)->ops->set_soap_fault_text(fault_reason, env, soap_text))
         
 #define AXIS2_SOAP_FAULT_REASON_GET_SOAP_TEXT(fault_reason , env) \
         ((fault_reason)->ops->get_soap_text(fault_reason, env)) 
@@ -135,16 +117,13 @@
 #define AXIS2_SOAP_FAULT_REASON_GET_BASE_NODE(fault_reason, env) \
         ((fault_reason)->ops->get_base_node(fault_reason, env))         
 
+/** internal functions , do not use */
+#define AXIS2_SOAP_FAULT_REASON_SET_SOAP_FAULT_TEXT(fault_reason , env, soap_text) \
+        ((fault_reason)->ops->set_soap_fault_text(fault_reason, env, soap_text))
+
 #define AXIS2_SOAP_FAULT_REASON_SET_BASE_NODE(fault_reason, env, node) \
         ((fault_reason)->ops->set_base_node(fault_reason, env, node))  
         
-#define AXIS2_SOAP_FAULT_REASON_GET_SOAP_VERSION(fault_reason, env) \
-        ((fault_reason)->ops->get_soap_version(fault_reason, env))
-        
-#define AXIS2_SOAP_FAULT_REASON_SET_SOAP_VERSION(fault_reason, env) \
-        ((fault_reason)->ops->set_soap_version(fault_reason, env))
-        
-
 #define AXIS2_SOAP_FAULT_REASON_SET_BUILDER(fault_reason, env, builder) \
         ((fault_reason)->ops->set_builder(fault_reason, env, builder))
 /** @} */

Modified: webservices/axis2/trunk/c/include/axis2_soap_fault_role.h
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/c/include/axis2_soap_fault_role.h?rev=385453&r1=385452&r2=385453&view=diff
==============================================================================
--- webservices/axis2/trunk/c/include/axis2_soap_fault_role.h (original)
+++ webservices/axis2/trunk/c/include/axis2_soap_fault_role.h Mon Mar 13 00:11:01 2006
@@ -73,16 +73,7 @@
         axis2_om_node_t* (AXIS2_CALL *get_base_node)
                                     (axis2_soap_fault_role_t *fault_role,
                                      axis2_env_t **env);
-                                 
-        int (AXIS2_CALL *get_soap_version)
-                                    (axis2_soap_fault_role_t *fault_role,
-                                     axis2_env_t **env);
-                                     
-        int (AXIS2_CALL *set_soap_version)
-                                    (axis2_soap_fault_role_t *fault_role,
-                                     axis2_env_t **env,
-                                     int soap_version);                                                                      
-                                                                                                                
+                                                                                                                   
     };      
 
   /**
@@ -124,24 +115,18 @@
 #define AXIS2_SOAP_FAULT_ROLE_FREE(fault_role , env) \
         ((fault_role)->ops->free_fn(fault_role, env))
 
-#define AXIS2_SOAP_FAULT_ROLE_SET_VALUE(fault_role , env, value) \
-        ((fault_role)->ops->set_role_value(fault_role, env, value))
-        
 #define AXIS2_SOAP_FAULT_ROLE_GET_VALUE(fault_role , env) \
         ((fault_role)->ops->get_role_value(fault_role, env)) 
         
 #define AXIS2_SOAP_FAULT_ROLE_GET_BASE_NODE(fault_role, env) \
         ((fault_role)->ops->get_base_node(fault_role, env))         
 
+/** internal functions , do not use */
 #define AXIS2_SOAP_FAULT_ROLE_SET_BASE_NODE(fault_role, env, node) \
         ((fault_role)->ops->set_base_node(fault_role, env, node)) 
 
-#define AXIS2_SOAP_FAULT_ROLE_GET_SOAP_VRESION(fault_role, env) \
-        ((fault_role)->ops->get_soap_version(fault_role, env)) 
-
-#define AXIS2_SOAP_FAULT_ROLE_SET_SOAP_VRESION(fault_role, env, version) \
-        ((fault_role)->ops->set_soap_version(fault_role, env, version))        
-                
+#define AXIS2_SOAP_FAULT_ROLE_SET_VALUE(fault_role , env, value) \
+        ((fault_role)->ops->set_role_value(fault_role, env, value))
 /** @} */
 
 #ifdef __cplusplus
@@ -149,5 +134,3 @@
 #endif
  
 #endif /* AXIS2_SOAP_FAULT_ROLE_H */
-
-

Modified: webservices/axis2/trunk/c/include/axis2_soap_fault_sub_code.h
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/c/include/axis2_soap_fault_sub_code.h?rev=385453&r1=385452&r2=385453&view=diff
==============================================================================
--- webservices/axis2/trunk/c/include/axis2_soap_fault_sub_code.h (original)
+++ webservices/axis2/trunk/c/include/axis2_soap_fault_sub_code.h Mon Mar 13 00:11:01 2006
@@ -53,21 +53,10 @@
         * @return satus of the op. AXIS2_SUCCESS on success 
         *         else AXIS2_FAILURE
         */
-
         axis2_status_t (AXIS2_CALL *free_fn)
                              (axis2_soap_fault_sub_code_t *fault_sub_code,
                               axis2_env_t **env);
                                      
-        axis2_status_t (AXIS2_CALL *set_value)
-                             (axis2_soap_fault_sub_code_t *fault_sub_code,
-                              axis2_env_t **env,
-                              struct axis2_soap_fault_value *fault_sub_code_val);
-
-        axis2_status_t (AXIS2_CALL *set_sub_code)
-                             (axis2_soap_fault_sub_code_t *fault_sub_code,
-                              axis2_env_t **env,
-                              axis2_soap_fault_sub_code_t *fault_subcode);                                                                         
-
         axis2_soap_fault_sub_code_t* (AXIS2_CALL *get_sub_code)                                         
                              (axis2_soap_fault_sub_code_t *fault_sub_code,
                               axis2_env_t **env);
@@ -76,30 +65,34 @@
                              (axis2_soap_fault_sub_code_t *fault_sub_code,
                               axis2_env_t **env);
                                      
+        axis2_om_node_t* (AXIS2_CALL *get_base_node)
+                             (axis2_soap_fault_sub_code_t *fault_sub_code,
+                              axis2_env_t **env);
+
+        /** following set functions are internal functions, do not use */
+
         axis2_status_t (AXIS2_CALL *set_base_node)
                              (axis2_soap_fault_sub_code_t *fault_sub_code,
                               axis2_env_t **env,
                               axis2_om_node_t *node);
-    
-        axis2_om_node_t* (AXIS2_CALL *get_base_node)
+
+        
+        axis2_status_t (AXIS2_CALL *set_sub_code)
                              (axis2_soap_fault_sub_code_t *fault_sub_code,
-                              axis2_env_t **env);
-                                 
-        int (AXIS2_CALL *get_soap_version)
+                              axis2_env_t **env,
+                              axis2_soap_fault_sub_code_t *fault_subcode);                                                                         
+                                         
+
+        axis2_status_t (AXIS2_CALL *set_value)
                              (axis2_soap_fault_sub_code_t *fault_sub_code,
-                              axis2_env_t **env); 
-                              
-        int (AXIS2_CALL *set_soap_version)
-                        (axis2_soap_fault_sub_code_t *fault_sub_code,
-                         axis2_env_t **env,
-                         int soap_version);      
+                              axis2_env_t **env,
+                              struct axis2_soap_fault_value *fault_sub_code_val);
+
                          
         axis2_status_t (AXIS2_CALL *set_builder)
                         (axis2_soap_fault_sub_code_t *fault_sub_code,
                          axis2_env_t **env,
                          struct axis2_soap_builder* builder);
-                                                                                                                      
-                                                                                                                
     };      
 
   /**
@@ -133,13 +126,6 @@
 /** free soap_fault_sub_code */
 #define AXIS2_SOAP_FAULT_SUB_CODE_FREE(fault_sub_code , env) \
         ((fault_sub_code)->ops->free_fn(fault_sub_code, env))
-
-#define AXIS2_SOAP_FAULT_SUB_CODE_SET_SUB_CODE(fault_sub_code , env, subcode) \
-        ((fault_sub_code)->ops->set_sub_code(fault_sub_code, env, subcode))
-
-#define AXIS2_SOAP_FAULT_SUB_CODE_SET_VALUE(fault_sub_code , env, value) \
-        ((fault_sub_code)->ops->set_value(fault_sub_code, env, value))
-
         
 #define AXIS2_SOAP_FAULT_SUB_CODE_GET_VALUE(fault_sub_code , env) \
         ((fault_sub_code)->ops->get_node(fault_sub_code, env)) 
@@ -150,17 +136,19 @@
 #define AXIS2_SOAP_FAULT_SUB_CODE_GET_BASE_NODE(fault_sub_code, env) \
         ((fault_sub_code)->ops->get_base_node(fault_sub_code, env))         
 
+/**follwing function macros are internal, do not use */
 #define AXIS2_SOAP_FAULT_SUB_CODE_SET_BASE_NODE(fault_sub_code, env, node) \
         ((fault_sub_code)->ops->set_base_node(fault_sub_code, env, node))
         
-#define AXIS2_SOAP_FAULT_SUB_CODE_GET_SOAP_VRESION(fault_sub_code, env) \
-        ((fault_sub_code)->ops->get_soap_version(fault_sub_code, env))
-
-#define AXIS2_SOAP_FAULT_SUB_CODE_SET_SOAP_VRESION(fault_sub_code, env, version) \
-        ((fault_sub_code)->ops->set_soap_version(fault_sub_code, env, version))        
-      
 #define AXIS2_SOAP_FAULT_SUB_CODE_SET_BUILDER(fault_sub_code, env, builder) \
         ((fault_sub_code)->ops->set_builder(fault_sub_code, env, builder))      
+
+#define AXIS2_SOAP_FAULT_SUB_CODE_SET_SUB_CODE(fault_sub_code , env, subcode) \
+        ((fault_sub_code)->ops->set_sub_code(fault_sub_code, env, subcode))
+
+#define AXIS2_SOAP_FAULT_SUB_CODE_SET_VALUE(fault_sub_code , env, value) \
+        ((fault_sub_code)->ops->set_value(fault_sub_code, env, value))
+
 /** @} */
 
 #ifdef __cplusplus
@@ -168,5 +156,3 @@
 #endif
 
 #endif /* AXIS2_SOAP_FAULT_SUB_CODE_H */
-
-

Modified: webservices/axis2/trunk/c/include/axis2_soap_fault_text.h
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/c/include/axis2_soap_fault_text.h?rev=385453&r1=385452&r2=385453&view=diff
==============================================================================
--- webservices/axis2/trunk/c/include/axis2_soap_fault_text.h (original)
+++ webservices/axis2/trunk/c/include/axis2_soap_fault_text.h Mon Mar 13 00:11:01 2006
@@ -63,7 +63,7 @@
         axis2_char_t* (AXIS2_CALL *get_lang)                                         
                                     (axis2_soap_fault_text_t *fault_text,
                                      axis2_env_t **env);
-                                     
+        /** this is an internal function for soap builder, do not use*/                             
         axis2_status_t (AXIS2_CALL *set_base_node)
                                     (axis2_soap_fault_text_t *fault_text,
                                      axis2_env_t **env,
@@ -72,16 +72,6 @@
         axis2_om_node_t* (AXIS2_CALL *get_base_node)
                                 (axis2_soap_fault_text_t *fault_text,
                                  axis2_env_t **env);
-                                 
-        int (AXIS2_CALL *get_soap_version)
-                                       (axis2_soap_fault_text_t *fault_text,
-                                        axis2_env_t **env);
-                                        
-        axis2_status_t (AXIS2_CALL *set_soap_version)
-                                       (axis2_soap_fault_text_t *fault_text,
-                                        axis2_env_t **env,
-                                        int soap_version);                                  
-                                                                                                                
     };      
 
   /**
@@ -103,7 +93,8 @@
 axis2_soap_fault_text_create_with_parent(axis2_env_t **env,
                             axis2_soap_fault_reason_t *fault);
                             
-
+/** this is an internal function for soap builder 
+    do not use externally */
 AXIS2_DECLARE(axis2_soap_fault_text_t *)
 axis2_soap_fault_text_create(axis2_env_t **env);
 
@@ -128,11 +119,6 @@
 #define AXIS2_SOAP_FAULT_TEXT_SET_BASE_NODE(fault_text, env, node) \
         ((fault_text)->ops->set_base_node(fault_text, env, node))
         
-#define AXIS2_SOAP_FAULT_TEXT_GET_SOAP_VERSION(fault_text, env) \
-        ((fault_text)->ops->get_soap_version(fault_text, env))
-        
-#define AXIS2_SOAP_FAULT_TEXT_SET_SOAP_VERSION(fault_text, env, version) \
-        ((fault_text)->ops->set_soap_version(fault_text, env, version))
 /** @} */
 
 #ifdef __cplusplus
@@ -140,4 +126,3 @@
 #endif 
  
 #endif /* AXIS2_SOAP_FAULT_TEXT_H */
-

Modified: webservices/axis2/trunk/c/include/axis2_soap_fault_value.h
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/c/include/axis2_soap_fault_value.h?rev=385453&r1=385452&r2=385453&view=diff
==============================================================================
--- webservices/axis2/trunk/c/include/axis2_soap_fault_value.h (original)
+++ webservices/axis2/trunk/c/include/axis2_soap_fault_value.h Mon Mar 13 00:11:01 2006
@@ -65,15 +65,6 @@
                              (axis2_soap_fault_value_t *fault_value,
                               axis2_env_t **env);
                               
-        int (AXIS2_CALL *get_soap_version)
-                             (axis2_soap_fault_value_t *fault_value,
-                              axis2_env_t **env);
-                              
-        axis2_status_t (AXIS2_CALL *set_soap_version)
-                             (axis2_soap_fault_value_t *fault_value,
-                              axis2_env_t **env,
-                              int soap_version);                                                              
-                                                                                                                
     };      
 
   /**
@@ -117,11 +108,6 @@
 #define AXIS2_SOAP_FAULT_VALUE_SET_BASE_NODE(fault_value, env, node) \
         ((fault_value)->ops->set_base_node(fault_value, env, node)) 
         
-#define AXIS2_SOAP_FAULT_VALUE_GET_SOAP_VERSION(fault_value, env) \
-        ((fault_value)->ops->get_soap_version(fault_value, env)) 
-        
-#define AXIS2_SOAP_FAULT_VALUE_SET_SOAP_VERSION(fault_value, env, version) \
-        ((fault_value)->ops->set_soap_version(fault_value, env, version))                
 /** @} */
 
 #ifdef __cplusplus

Modified: webservices/axis2/trunk/c/include/axis2_soap_header.h
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/c/include/axis2_soap_header.h?rev=385453&r1=385452&r2=385453&view=diff
==============================================================================
--- webservices/axis2/trunk/c/include/axis2_soap_header.h (original)
+++ webservices/axis2/trunk/c/include/axis2_soap_header.h Mon Mar 13 00:11:01 2006
@@ -155,16 +155,23 @@
          */
         int  (AXIS2_CALL *get_soap_version) (axis2_soap_header_t *header,
                                              axis2_env_t **env);
+        
+        /** this is an internal function, only for soap code */
+        int (AXIS2_CALL *set_soap_version)(axis2_soap_header_t *header,
+                                           axis2_env_t **env,
+                                           int soap_version);
          
         axis2_status_t (AXIS2_CALL *set_header_block)
                                             (axis2_soap_header_t *header,
                                              axis2_env_t **env,
-                                             struct axis2_soap_header_block* header_block);                                                                                                     axis2_status_t (AXIS2_CALL *set_builder)(axis2_soap_header_t *header,
+                                             struct axis2_soap_header_block* header_block);
+       
+       axis2_status_t (AXIS2_CALL *set_builder)(axis2_soap_header_t *header,
                                                 axis2_env_t **env,
                                                 struct axis2_soap_builder* builder);
 
-        axis2_hash_t* (AXIS2_CALL *get_all_header_blocks)(axis2_soap_header_t *header,
-                                                          axis2_env_t **env);                                                
+       axis2_hash_t* (AXIS2_CALL *get_all_header_blocks)(axis2_soap_header_t *header,
+                                                         axis2_env_t **env);                                                
                                          
     };
 
@@ -231,6 +238,10 @@
 
 #define AXIS2_SOAP_HEADER_GET_ALL_HEADER_BLOCKS(header, env) \
         ((header)->ops->get_all_header_blocks(header, env))
+
+#define AXIS2_SOAP_HEADER_SET_SOAP_VERSION(header, env, soap_version) \
+        ((header)->ops->set_soap_version(header, env, soap_version))
+        
 /** @} */
 
 #ifdef __cplusplus

Modified: webservices/axis2/trunk/c/include/axis2_soap_header_block.h
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/c/include/axis2_soap_header_block.h?rev=385453&r1=385452&r2=385453&view=diff
==============================================================================
--- webservices/axis2/trunk/c/include/axis2_soap_header_block.h (original)
+++ webservices/axis2/trunk/c/include/axis2_soap_header_block.h Mon Mar 13 00:11:01 2006
@@ -121,6 +121,12 @@
         int (AXIS2_CALL *get_soap_version)  
                             (axis2_soap_header_block_t *header_block,
                              axis2_env_t **env);
+
+        axis2_status_t (AXIS2_CALL *set_soap_version)
+                            (axis2_soap_header_block_t *header_block,
+                             axis2_env_t **env,
+                             int soap_version);
+        
        
     };
 
@@ -135,10 +141,11 @@
        
     };
 
-  /**
-    * creates a soap struct 
-    * @param env Environment. MUST NOT be NULL
-    */
+/**
+* creates a soap struct 
+* @param env Environment. MUST NOT be NULL
+* this is an internal function.    
+*/
 
 AXIS2_DECLARE(axis2_soap_header_block_t *)
 axis2_soap_header_block_create(axis2_env_t **env);
@@ -195,6 +202,9 @@
             attr_name, soap_envelope_namespace_uri)  \
         ((header_block)->ops->set_attribute(header_block, env, \
             attr_name, soap_envelope_namespace_uri))            
+
+#define AXIS2_SOAP_HEADER_BLOCK_SET_SOAP_VERSION(header_block, env, soap_version) \
+        ((header_block)->ops->set_soap_version(header_block, env, soap_version))
 /** @} */
 
 #ifdef __cplusplus

Modified: webservices/axis2/trunk/c/modules/xml/om/Makefile.am
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/c/modules/xml/om/Makefile.am?rev=385453&r1=385452&r2=385453&view=diff
==============================================================================
--- webservices/axis2/trunk/c/modules/xml/om/Makefile.am (original)
+++ webservices/axis2/trunk/c/modules/xml/om/Makefile.am Mon Mar 13 00:11:01 2006
@@ -20,4 +20,5 @@
 INCLUDES = -I$(top_builddir)/include \
             -I$(top_builddir)/modules/util \
             -I$(top_builddir)/modules/xml/parser \
-            -I$(top_builddir)/modules/platforms
+            -I$(top_builddir)/modules/platforms \
+            -I$(top_builddir)/modules/xml/om

Added: webservices/axis2/trunk/c/modules/xml/om/axis2_om_node_internal.h
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/c/modules/xml/om/axis2_om_node_internal.h?rev=385453&view=auto
==============================================================================
--- webservices/axis2/trunk/c/modules/xml/om/axis2_om_node_internal.h (added)
+++ webservices/axis2/trunk/c/modules/xml/om/axis2_om_node_internal.h Mon Mar 13 00:11:01 2006
@@ -0,0 +1,155 @@
+/*
+ * 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.
+ */
+ 
+ #ifndef AXIS2_OM_NODE_INTERNAL_H
+ #define AXIS2_OM_NODE_INTERNAL_H
+ 
+ 
+ /** @defgroup axis2_om AXIOM (Axis Object Model)
+  * @ingroup axis2
+  * @{
+  */
+  
+/** @} */
+
+#include <axis2_om_node.h>
+
+#ifdef __cplusplus
+extern "C"
+{
+#endif
+  
+/**
+ * @defgroup axis2_om_node  OM Node
+ * @ingroup axis2_om 
+ * @{
+ */
+struct axis2_om_document;
+struct axis2_om_stax_builder;    
+    
+/**
+ * Sets a parent node to a given node, if a parent already exist for this node
+ * then it is detached before seting the parent internal function;
+ * @param om_node child node to whom a parent to be added. , cannot be NULL.
+ * @param env Environment. MUST NOT be NULL, .
+ * @param parent_node the node that will be set as parent. , cannot be NULL.
+ * @return satus of the op. AXIS2_SUCCESS on success else AXIS2_FAILURE
+ */
+
+AXIS2_DECLARE(axis2_status_t)
+axis2_om_node_set_parent (axis2_om_node_t * om_node,
+                          axis2_env_t **env,
+                          axis2_om_node_t * parent);
+
+/**
+*   sets a node as first child of om_node
+* @param om_node om_node
+* @param env environment, MUST NOT be NULL.
+* @param first_child child to be set as first child
+*/  
+AXIS2_DECLARE(axis2_status_t)
+axis2_om_node_set_first_child(axis2_om_node_t *om_node,
+                              axis2_env_t **env,
+                              axis2_om_node_t *first_child); 
+/**
+* set previous sibling
+* @param om_node 
+* @param env environment, MUST NOT be NULL.
+* @param prev_sibling 
+* @return status of the op, AXIS2_SUCCESS on success
+*               AXIS2_FAILURE on error
+*/
+    
+     
+AXIS2_DECLARE(axis2_status_t)  
+axis2_om_node_set_previous_sibling(axis2_om_node_t *om_node,                                  
+                                   axis2_env_t **env,
+                                   axis2_om_node_t *prev_sibling); 
+/**
+* set next sibling
+* @param om_node 
+* @param env environment, MUST NOT be NULL.
+* @param last_sibling 
+* @return status of the op, AXIS2_SUCCESS on success,
+*                   AXIS2_FAILURE on error
+*/                                                  
+ 
+AXIS2_DECLARE(axis2_status_t)
+axis2_om_node_set_next_sibling(axis2_om_node_t *om_node,
+                               axis2_env_t **env,
+                               axis2_om_node_t *next_sibling);
+/**
+*   set node type
+* @param om_node    
+* @param env environment, MUST NOT be NULL.
+* @param type type of the node
+* @return status code of the op AXIS2_SUCCESS on success,
+*                       AXIS2_FAILURE on error
+*/
+AXIS2_DECLARE(axis2_status_t) 
+axis2_om_node_set_node_type(axis2_om_node_t *om_node,
+                            axis2_env_t **env,
+                            axis2_om_types_t type);
+
+/**
+* set data element
+* @param om_node  node struct  
+* @param env environment, MUST NOT be NULL.
+* @param data_element 
+* @return status code of the op AXIS2_SUCCESS on success,
+*                       AXIS2_FAILURE on error
+*/
+AXIS2_DECLARE(axis2_status_t) 
+axis2_om_node_set_data_element(axis2_om_node_t *om_node,
+                               axis2_env_t **env,
+                               void* data_element);
+/**
+* set build status, if the node if completety build build status is
+* set to AXIS2_TRUE , otherwise AXIS2_FALSE  
+* @param om_node 
+* @param env environment, MUST NOT be NULL.
+* @param done                   
+*/                                    
+AXIS2_DECLARE(axis2_status_t)
+axis2_om_node_set_build_status(axis2_om_node_t *om_node,
+                               axis2_env_t **env,
+                               axis2_bool_t done);  
+  
+/**
+* This functions is only to be used by builder
+* do not use this function
+*/  
+AXIS2_DECLARE(axis2_status_t)
+axis2_om_node_set_document(axis2_om_node_t *om_node,
+                           axis2_env_t **env,
+                           struct axis2_om_document *om_doc);
+/**
+*    sets the builder 
+*
+*/                           
+AXIS2_DECLARE(axis2_status_t)
+axis2_om_node_set_builder(axis2_om_node_t *om_node,
+                          axis2_env_t **env,
+                          struct axis2_om_stax_builder *builder);                           
+
+  
+/** @} */
+    
+#ifdef __cplusplus
+}
+#endif
+
+#endif /** AXIS2_OM_NODE_INTERNAL_H */

Added: webservices/axis2/trunk/c/modules/xml/om/axis2_om_stax_builder_internal.h
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/c/modules/xml/om/axis2_om_stax_builder_internal.h?rev=385453&view=auto
==============================================================================
--- webservices/axis2/trunk/c/modules/xml/om/axis2_om_stax_builder_internal.h (added)
+++ webservices/axis2/trunk/c/modules/xml/om/axis2_om_stax_builder_internal.h Mon Mar 13 00:11:01 2006
@@ -0,0 +1,68 @@
+/*
+ * 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.
+ */
+ 
+ #ifndef AXIS2_OM_STAX_BUILDER_INTERNAL_H
+ #define AXIS2_OM_STAX_BUILDER_INTERNAL_H
+ 
+ 
+ /** @defgroup axis2_om AXIOM (Axis Object Model)
+  * @ingroup axis2
+  * @{
+  */
+  
+/** @} */
+
+#include <axis2_om_stax_builder.h>
+
+#ifdef __cplusplus
+extern "C"
+{
+#endif
+  
+/**
+ * @defgroup axis2_om_stax builder
+ * @ingroup axis2_om 
+ * @{
+ */
+    
+AXIS2_DECLARE(int)
+axis2_om_stax_builder_get_current_event(axis2_om_stax_builder_t *builder,
+                                        axis2_env_t **env);
+                                        
+AXIS2_DECLARE(axis2_status_t)
+axis2_om_stax_builder_set_lastnode(axis2_om_stax_builder_t *builder,
+                                    axis2_env_t **env,
+                                    axis2_om_node_t *om_node);
+                                    
+AXIS2_DECLARE(int)
+axis2_om_stax_builder_get_element_level(axis2_om_stax_builder_t* builder,
+                                        axis2_env_t **env); 
+                                            
+AXIS2_DECLARE(axis2_status_t)
+axis2_om_stax_builder_set_element_level(axis2_om_stax_builder_t* builder,
+                                        axis2_env_t **env,
+                                        int element_level);  
+AXIS2_DECLARE(axis2_om_node_t*)
+axis2_om_stax_builder_get_lastnode(axis2_om_stax_builder_t *builder,
+                                   axis2_env_t **env);
+  
+/** @} */
+    
+#ifdef __cplusplus
+}
+#endif
+
+#endif /** AXIS2_OM_STAX_BUILDER_INTERNAL_H */

Modified: webservices/axis2/trunk/c/modules/xml/om/om_children_qname_iterator.c
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/c/modules/xml/om/om_children_qname_iterator.c?rev=385453&r1=385452&r2=385453&view=diff
==============================================================================
--- webservices/axis2/trunk/c/modules/xml/om/om_children_qname_iterator.c (original)
+++ webservices/axis2/trunk/c/modules/xml/om/om_children_qname_iterator.c Mon Mar 13 00:11:01 2006
@@ -138,7 +138,7 @@
         AXIS2_FREE((*env)->allocator, iterator->ops);
     if(iterator_impl->given_qname)
     {
-        AXIS2_QNAME_FREE(iterator_impl->given_qname, env);
+        /**AXIS2_QNAME_FREE(iterator_impl->given_qname, env); */
         iterator_impl->given_qname = NULL;
     }
     AXIS2_FREE((*env)->allocator, iterator_impl);

Modified: webservices/axis2/trunk/c/modules/xml/om/om_comment.c
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/c/modules/xml/om/om_comment.c?rev=385453&r1=385452&r2=385453&view=diff
==============================================================================
--- webservices/axis2/trunk/c/modules/xml/om/om_comment.c (original)
+++ webservices/axis2/trunk/c/modules/xml/om/om_comment.c Mon Mar 13 00:11:01 2006
@@ -15,6 +15,7 @@
  */
 
 #include <axis2_om_comment.h>
+#include <axis2_om_node_internal.h>
 #include <axis2_string.h>
 
 axis2_status_t AXIS2_CALL
@@ -91,8 +92,8 @@
         }
     }
 
-    AXIS2_OM_NODE_SET_DATA_ELEMENT((*node), env, comment);
-    AXIS2_OM_NODE_SET_NODE_TYPE((*node), env, AXIS2_OM_COMMENT);
+    axis2_om_node_set_data_element((*node), env, comment);
+    axis2_om_node_set_node_type((*node), env, AXIS2_OM_COMMENT);
     
     if (parent)
     {

Modified: webservices/axis2/trunk/c/modules/xml/om/om_doctype.c
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/c/modules/xml/om/om_doctype.c?rev=385453&r1=385452&r2=385453&view=diff
==============================================================================
--- webservices/axis2/trunk/c/modules/xml/om/om_doctype.c (original)
+++ webservices/axis2/trunk/c/modules/xml/om/om_doctype.c Mon Mar 13 00:11:01 2006
@@ -16,6 +16,7 @@
 
 #include <axis2_om_doctype.h>
 #include <axis2_string.h>
+#include <axis2_om_node_internal.h>
 
 axis2_status_t AXIS2_CALL
 axis2_om_doctype_free (axis2_om_doctype_t *om_doctype,
@@ -93,8 +94,8 @@
         }
     }
 
-    AXIS2_OM_NODE_SET_DATA_ELEMENT((*node), env, doctype);
-    AXIS2_OM_NODE_SET_NODE_TYPE((*node), env, AXIS2_OM_DOCTYPE);
+    axis2_om_node_set_data_element((*node), env, doctype);
+    axis2_om_node_set_node_type((*node), env, AXIS2_OM_DOCTYPE);
 
     if (parent)
     {

Modified: webservices/axis2/trunk/c/modules/xml/om/om_document.c
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/c/modules/xml/om/om_document.c?rev=385453&r1=385452&r2=385453&view=diff
==============================================================================
--- webservices/axis2/trunk/c/modules/xml/om/om_document.c (original)
+++ webservices/axis2/trunk/c/modules/xml/om/om_document.c Mon Mar 13 00:11:01 2006
@@ -234,7 +234,9 @@
     AXIS2_ENV_CHECK(env, NULL);
   
     document = AXIS2_INTF_TO_IMPL(om_document);
-    
+    if(!document->builder)
+        return NULL;
+   
     if (!(document->root_element))
     {
         last_child = AXIS2_OM_STAX_BUILDER_NEXT (document->builder, env);