You are viewing a plain text version of this content. The canonical link for it is here.
Posted to c-commits@axis.apache.org by da...@apache.org on 2010/06/29 10:57:06 UTC

svn commit: r958884 [2/9] - in /axis/axis2/c/core/trunk: axiom/src/om/ axiom/src/soap/ samples/client/amqp/echo/ samples/client/amqp/mtom/ samples/client/amqp/notify/ src/core/deployment/ src/core/transport/amqp/receiver/ src/core/transport/amqp/receiv...

Modified: axis/axis2/c/core/trunk/samples/client/amqp/echo/echo_non_blocking_dual.c
URL: http://svn.apache.org/viewvc/axis/axis2/c/core/trunk/samples/client/amqp/echo/echo_non_blocking_dual.c?rev=958884&r1=958883&r2=958884&view=diff
==============================================================================
--- axis/axis2/c/core/trunk/samples/client/amqp/echo/echo_non_blocking_dual.c (original)
+++ axis/axis2/c/core/trunk/samples/client/amqp/echo/echo_non_blocking_dual.c Tue Jun 29 08:57:05 2010
@@ -1,235 +1,235 @@
-
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You 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.
- */
-
-#include "echo_util.h"
-#include <axis2_util.h>
-#include <axiom_soap.h>
-#include <axis2_client.h>
-
-#define MAX_COUNT  10
-
-/* my on_complete callback function */
-axis2_status_t AXIS2_CALL echo_callback_on_complete(
-    struct axis2_callback * callback,
-    const axutil_env_t * env);
-
-/* my on_error callback function */
-axis2_status_t AXIS2_CALL echo_callback_on_error(
-    struct axis2_callback *callback,
-    const axutil_env_t * env,
-    int exception);
-
-/* to check whether the callback is completed */
-int isComplete = 0;
-
-int
-main(
-    int argc,
-    char **argv)
-{
-    const axutil_env_t *env = NULL;
-    const axis2_char_t *address = NULL;
-    axis2_endpoint_ref_t *endpoint_ref = NULL;
-    axis2_endpoint_ref_t *reply_to = NULL;
-    axis2_options_t *options = NULL;
-    const axis2_char_t *client_home = NULL;
-    axis2_svc_client_t *svc_client = NULL;
-    axiom_node_t *payload = NULL;
-    axis2_callback_t *callback = NULL;
-    int count = 0;
-
-    /* Set up the environment */
-    env =
-        axutil_env_create_all("echo_non_blocking_dual_amqp.log",
-                              AXIS2_LOG_LEVEL_TRACE);
-
-    /* Set end point reference of echo service */
-    address = "amqp://localhost:5672/axis2/services/echo";
-    if (argc > 1)
-        address = argv[1];
-    if (axutil_strcmp(address, "-h") == 0)
-    {
-        printf("Usage : %s [endpoint_url]\n", argv[0]);
-        printf("use -h for help\n");
-        return 0;
-    }
-    printf("Using endpoint : %s\n", address);
-
-    /* Create EPR with given address */
-    endpoint_ref = axis2_endpoint_ref_create(env, address);
-
-    /* Setup options */
-    options = axis2_options_create(env);
-    axis2_options_set_to(options, env, endpoint_ref);
-    axis2_options_set_use_separate_listener(options, env, AXIS2_TRUE);
-
-    /* Seperate listner needs addressing, hence addressing stuff in options */
-    axis2_options_set_action(options, env,
-                             "http://ws.apache.org/axis2/c/samples/echoString");
-    reply_to =
-        axis2_endpoint_ref_create(env,
-                                  "amqp://localhost:5672/axis2/services/__ANONYMOUS_SERVICE__");
-    axis2_options_set_reply_to(options, env, reply_to);
-
-	axis2_options_set_transport_in_protocol(options, env, AXIS2_TRANSPORT_ENUM_AMQP);
-
-    /* Set up deploy folder. It is from the deploy folder, the configuration is picked up
-     * using the axis2.xml file.
-     * In this sample client_home points to the Axis2/C default deploy folder. The client_home can 
-     * be different from this folder on your system. For example, you may have a different folder 
-     * (say, my_client_folder) with its own axis2.xml file. my_client_folder/modules will have the 
-     * modules that the client uses
-     */
-    client_home = AXIS2_GETENV("AXIS2C_HOME");
-    if (!client_home || !strcmp(client_home, ""))
-        client_home = "../..";
-
-    /* Create service client */
-    svc_client = axis2_svc_client_create(env, client_home);
-    if (!svc_client)
-    {
-        printf
-            ("Error creating service client, Please check AXIS2C_HOME again\n");
-        AXIS2_LOG_ERROR(env->log, AXIS2_LOG_SI,
-                        "Stub invoke FAILED: Error code:" " %d :: %s",
-                        env->error->error_number,
-                        AXIS2_ERROR_GET_MESSAGE(env->error));
-        return -1;
-    }
-
-    /* Set service client options */
-    axis2_svc_client_set_options(svc_client, env, options);
-
-    axis2_svc_client_engage_module(svc_client, env, AXIS2_MODULE_ADDRESSING);
-    /*axis2_svc_client_engage_module(svc_client, env, "sandesha2"); */
-
-    /* Build the SOAP request message payload using OM API. */
-    payload = build_om_payload_for_echo_svc(env);
-
-    /* Create the callback object with default on_complete and on_error
-       callback functions */
-    callback = axis2_callback_create(env);
-
-    /* Set our on_complete fucntion pointer to the callback object */
-    axis2_callback_set_on_complete(callback, echo_callback_on_complete);
-
-    /* Set our on_error function pointer to the callback object */
-    axis2_callback_set_on_error(callback, echo_callback_on_error);
-
-    /* Send request */
-    axis2_svc_client_send_receive_non_blocking(svc_client, env,
-                                               payload, callback);
-
-    /** Wait till callback is complete. Simply keep the parent thread running
-       until our on_complete or on_error is invoked */
-    while (count < MAX_COUNT)
-    {
-        if (isComplete)
-        {
-            /* We are done with the callback */
-            break;
-        }
-		
-		AXIS2_SLEEP(1);
-        count++;
-    }
-
-    if (!(count < MAX_COUNT))
-    {
-        printf("\necho client invoke FAILED. Counter timed out.\n");
-    }
-
-    if (svc_client)
-    {
-        AXIS2_SLEEP(1);
-        axis2_svc_client_free(svc_client, env);
-        svc_client = NULL;
-    }
-
-    if (env)
-    {
-        axutil_env_free((axutil_env_t *) env);
-        env = NULL;
-    }
-
-    return 0;
-}
-
-axis2_status_t AXIS2_CALL
-echo_callback_on_complete(
-    struct axis2_callback * callback,
-    const axutil_env_t * env)
-{
-
-    /** SOAP response has arrived here; get the soap envelope
-      from the callback object and do whatever you want to do with it */
-
-    axiom_soap_envelope_t *soap_envelope = NULL;
-    axiom_node_t *ret_node = NULL;
-    axis2_status_t status = AXIS2_SUCCESS;
-
-    soap_envelope = axis2_callback_get_envelope(callback, env);
-
-    if (!soap_envelope)
-    {
-        AXIS2_LOG_ERROR(env->log, AXIS2_LOG_SI,
-                        "Stub invoke FAILED: Error code:" " %d :: %s",
-                        env->error->error_number,
-                        AXIS2_ERROR_GET_MESSAGE(env->error));
-        printf("echo stub invoke FAILED!\n");
-        status = AXIS2_FAILURE;
-    }
-    else
-    {
-        ret_node = axiom_soap_envelope_get_base_node(soap_envelope, env);
-
-        if (!ret_node)
-        {
-            AXIS2_LOG_ERROR(env->log, AXIS2_LOG_SI,
-                            "Stub invoke FAILED: Error code:" " %d :: %s",
-                            env->error->error_number,
-                            AXIS2_ERROR_GET_MESSAGE(env->error));
-            printf("echo stub invoke FAILED!\n");
-            status = AXIS2_FAILURE;
-        }
-        else
-        {
-            axis2_char_t *om_str = NULL;
-            om_str = axiom_node_to_string(ret_node, env);
-            if (om_str)
-                printf("\nReceived OM : %s\n", om_str);
-            printf("\necho client invoke SUCCESSFUL!\n");
-        }
-    }
-    isComplete = 1;
-    return status;
-}
-
-axis2_status_t AXIS2_CALL
-echo_callback_on_error(
-    struct axis2_callback * callback,
-    const axutil_env_t * env,
-    int exception)
-{
-
-    /** take necessary action on error */
-    printf("\nEcho client invoke FAILED. Error code:%d ::%s", exception,
-           AXIS2_ERROR_GET_MESSAGE(env->error));
-    isComplete = 1;
-    return AXIS2_SUCCESS;
-}
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You 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.
+ */
+
+#include "echo_util.h"
+#include <axis2_util.h>
+#include <axiom_soap.h>
+#include <axis2_client.h>
+
+#define MAX_COUNT  10
+
+/* my on_complete callback function */
+axis2_status_t AXIS2_CALL echo_callback_on_complete(
+    struct axis2_callback * callback,
+    const axutil_env_t * env);
+
+/* my on_error callback function */
+axis2_status_t AXIS2_CALL echo_callback_on_error(
+    struct axis2_callback *callback,
+    const axutil_env_t * env,
+    int exception);
+
+/* to check whether the callback is completed */
+int isComplete = 0;
+
+int
+main(
+    int argc,
+    char **argv)
+{
+    const axutil_env_t *env = NULL;
+    const axis2_char_t *address = NULL;
+    axis2_endpoint_ref_t *endpoint_ref = NULL;
+    axis2_endpoint_ref_t *reply_to = NULL;
+    axis2_options_t *options = NULL;
+    const axis2_char_t *client_home = NULL;
+    axis2_svc_client_t *svc_client = NULL;
+    axiom_node_t *payload = NULL;
+    axis2_callback_t *callback = NULL;
+    int count = 0;
+
+    /* Set up the environment */
+    env =
+        axutil_env_create_all("echo_non_blocking_dual_amqp.log",
+                              AXIS2_LOG_LEVEL_TRACE);
+
+    /* Set end point reference of echo service */
+    address = "amqp://localhost:5672/axis2/services/echo";
+    if (argc > 1)
+        address = argv[1];
+    if (axutil_strcmp(address, "-h") == 0)
+    {
+        printf("Usage : %s [endpoint_url]\n", argv[0]);
+        printf("use -h for help\n");
+        return 0;
+    }
+    printf("Using endpoint : %s\n", address);
+
+    /* Create EPR with given address */
+    endpoint_ref = axis2_endpoint_ref_create(env, address);
+
+    /* Setup options */
+    options = axis2_options_create(env);
+    axis2_options_set_to(options, env, endpoint_ref);
+    axis2_options_set_use_separate_listener(options, env, AXIS2_TRUE);
+
+    /* Seperate listner needs addressing, hence addressing stuff in options */
+    axis2_options_set_action(options, env,
+                             "http://ws.apache.org/axis2/c/samples/echoString");
+    reply_to =
+        axis2_endpoint_ref_create(env,
+                                  "amqp://localhost:5672/axis2/services/__ANONYMOUS_SERVICE__");
+    axis2_options_set_reply_to(options, env, reply_to);
+
+	axis2_options_set_transport_in_protocol(options, env, AXIS2_TRANSPORT_ENUM_AMQP);
+
+    /* Set up deploy folder. It is from the deploy folder, the configuration is picked up
+     * using the axis2.xml file.
+     * In this sample client_home points to the Axis2/C default deploy folder. The client_home can 
+     * be different from this folder on your system. For example, you may have a different folder 
+     * (say, my_client_folder) with its own axis2.xml file. my_client_folder/modules will have the 
+     * modules that the client uses
+     */
+    client_home = AXIS2_GETENV("AXIS2C_HOME");
+    if (!client_home || !strcmp(client_home, ""))
+        client_home = "../..";
+
+    /* Create service client */
+    svc_client = axis2_svc_client_create(env, client_home);
+    if (!svc_client)
+    {
+        printf
+            ("Error creating service client, Please check AXIS2C_HOME again\n");
+        AXIS2_LOG_ERROR(env->log, AXIS2_LOG_SI,
+                        "Stub invoke FAILED: Error code:" " %d :: %s",
+                        env->error->error_number,
+                        AXIS2_ERROR_GET_MESSAGE(env->error));
+        return -1;
+    }
+
+    /* Set service client options */
+    axis2_svc_client_set_options(svc_client, env, options);
+
+    axis2_svc_client_engage_module(svc_client, env, AXIS2_MODULE_ADDRESSING);
+    /*axis2_svc_client_engage_module(svc_client, env, "sandesha2"); */
+
+    /* Build the SOAP request message payload using OM API. */
+    payload = build_om_payload_for_echo_svc(env);
+
+    /* Create the callback object with default on_complete and on_error
+       callback functions */
+    callback = axis2_callback_create(env);
+
+    /* Set our on_complete fucntion pointer to the callback object */
+    axis2_callback_set_on_complete(callback, echo_callback_on_complete);
+
+    /* Set our on_error function pointer to the callback object */
+    axis2_callback_set_on_error(callback, echo_callback_on_error);
+
+    /* Send request */
+    axis2_svc_client_send_receive_non_blocking(svc_client, env,
+                                               payload, callback);
+
+    /** Wait till callback is complete. Simply keep the parent thread running
+       until our on_complete or on_error is invoked */
+    while (count < MAX_COUNT)
+    {
+        if (isComplete)
+        {
+            /* We are done with the callback */
+            break;
+        }
+		
+		AXIS2_SLEEP(1);
+        count++;
+    }
+
+    if (!(count < MAX_COUNT))
+    {
+        printf("\necho client invoke FAILED. Counter timed out.\n");
+    }
+
+    if (svc_client)
+    {
+        AXIS2_SLEEP(1);
+        axis2_svc_client_free(svc_client, env);
+        svc_client = NULL;
+    }
+
+    if (env)
+    {
+        axutil_env_free((axutil_env_t *) env);
+        env = NULL;
+    }
+
+    return 0;
+}
+
+axis2_status_t AXIS2_CALL
+echo_callback_on_complete(
+    struct axis2_callback * callback,
+    const axutil_env_t * env)
+{
+
+    /** SOAP response has arrived here; get the soap envelope
+      from the callback object and do whatever you want to do with it */
+
+    axiom_soap_envelope_t *soap_envelope = NULL;
+    axiom_node_t *ret_node = NULL;
+    axis2_status_t status = AXIS2_SUCCESS;
+
+    soap_envelope = axis2_callback_get_envelope(callback, env);
+
+    if (!soap_envelope)
+    {
+        AXIS2_LOG_ERROR(env->log, AXIS2_LOG_SI,
+                        "Stub invoke FAILED: Error code:" " %d :: %s",
+                        env->error->error_number,
+                        AXIS2_ERROR_GET_MESSAGE(env->error));
+        printf("echo stub invoke FAILED!\n");
+        status = AXIS2_FAILURE;
+    }
+    else
+    {
+        ret_node = axiom_soap_envelope_get_base_node(soap_envelope, env);
+
+        if (!ret_node)
+        {
+            AXIS2_LOG_ERROR(env->log, AXIS2_LOG_SI,
+                            "Stub invoke FAILED: Error code:" " %d :: %s",
+                            env->error->error_number,
+                            AXIS2_ERROR_GET_MESSAGE(env->error));
+            printf("echo stub invoke FAILED!\n");
+            status = AXIS2_FAILURE;
+        }
+        else
+        {
+            axis2_char_t *om_str = NULL;
+            om_str = axiom_node_to_string(ret_node, env);
+            if (om_str)
+                printf("\nReceived OM : %s\n", om_str);
+            printf("\necho client invoke SUCCESSFUL!\n");
+        }
+    }
+    isComplete = 1;
+    return status;
+}
+
+axis2_status_t AXIS2_CALL
+echo_callback_on_error(
+    struct axis2_callback * callback,
+    const axutil_env_t * env,
+    int exception)
+{
+
+    /** take necessary action on error */
+    printf("\nEcho client invoke FAILED. Error code:%d ::%s", exception,
+           AXIS2_ERROR_GET_MESSAGE(env->error));
+    isComplete = 1;
+    return AXIS2_SUCCESS;
+}

Modified: axis/axis2/c/core/trunk/samples/client/amqp/echo/echo_util.c
URL: http://svn.apache.org/viewvc/axis/axis2/c/core/trunk/samples/client/amqp/echo/echo_util.c?rev=958884&r1=958883&r2=958884&view=diff
==============================================================================
--- axis/axis2/c/core/trunk/samples/client/amqp/echo/echo_util.c (original)
+++ axis/axis2/c/core/trunk/samples/client/amqp/echo/echo_util.c Tue Jun 29 08:57:05 2010
@@ -1,47 +1,47 @@
-
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You 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.
- */
-
-#include "echo_util.h"
-
-/* build SOAP request message content using OM */
-axiom_node_t*
-build_om_payload_for_echo_svc (const axutil_env_t* env)
-{
-    axiom_node_t* echo_om_node = NULL;
-    axiom_element_t* echo_om_ele = NULL;
-    axiom_node_t* text_om_node = NULL;
-    axiom_element_t* text_om_ele = NULL;
-    axiom_namespace_t* ns1 = NULL;
-    axis2_char_t* om_str = NULL;
-
-    ns1 = axiom_namespace_create (env, "http://ws.apache.org/axis2/services/echo",
-                                  "ns1");
-    echo_om_ele = axiom_element_create (env, NULL, "echoString", ns1, &echo_om_node);
-    text_om_ele = axiom_element_create (env, echo_om_node, "text", NULL, &text_om_node);
-    axiom_element_set_text (text_om_ele, env, "Hello World!", text_om_node);
-
-    om_str = axiom_node_to_string (echo_om_node, env);
-    if (om_str)
-        printf ("\nSending OM : %s\n", om_str);
-
-    AXIS2_FREE (env->allocator, om_str);
-
-    return echo_om_node;
-}
-
-
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You 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.
+ */
+
+#include "echo_util.h"
+
+/* build SOAP request message content using OM */
+axiom_node_t*
+build_om_payload_for_echo_svc (const axutil_env_t* env)
+{
+    axiom_node_t* echo_om_node = NULL;
+    axiom_element_t* echo_om_ele = NULL;
+    axiom_node_t* text_om_node = NULL;
+    axiom_element_t* text_om_ele = NULL;
+    axiom_namespace_t* ns1 = NULL;
+    axis2_char_t* om_str = NULL;
+
+    ns1 = axiom_namespace_create (env, "http://ws.apache.org/axis2/services/echo",
+                                  "ns1");
+    echo_om_ele = axiom_element_create (env, NULL, "echoString", ns1, &echo_om_node);
+    text_om_ele = axiom_element_create (env, echo_om_node, "text", NULL, &text_om_node);
+    axiom_element_set_text (text_om_ele, env, "Hello World!", text_om_node);
+
+    om_str = axiom_node_to_string (echo_om_node, env);
+    if (om_str)
+        printf ("\nSending OM : %s\n", om_str);
+
+    AXIS2_FREE (env->allocator, om_str);
+
+    return echo_om_node;
+}
+
+

Modified: axis/axis2/c/core/trunk/samples/client/amqp/echo/echo_util.h
URL: http://svn.apache.org/viewvc/axis/axis2/c/core/trunk/samples/client/amqp/echo/echo_util.h?rev=958884&r1=958883&r2=958884&view=diff
==============================================================================
--- axis/axis2/c/core/trunk/samples/client/amqp/echo/echo_util.h (original)
+++ axis/axis2/c/core/trunk/samples/client/amqp/echo/echo_util.h Tue Jun 29 08:57:05 2010
@@ -1,54 +1,54 @@
-
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You 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_UG_ECHO_UTIL_H
-#define AXIS2_UG_ECHO_UTIL_H
-
-#include <stdio.h>
-#include <axiom.h>
-
-axiom_node_t* build_om_payload_for_echo_svc (const axutil_env_t * env);
-
-#endif
-
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You 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_UG_ECHO_UTIL_H
-#define AXIS2_UG_ECHO_UTIL_H
-
-#include <stdio.h>
-#include <axiom.h>
-
-axiom_node_t* build_om_payload_for_echo_svc (const axutil_env_t * env);
-
-#endif
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You 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_UG_ECHO_UTIL_H
+#define AXIS2_UG_ECHO_UTIL_H
+
+#include <stdio.h>
+#include <axiom.h>
+
+axiom_node_t* build_om_payload_for_echo_svc (const axutil_env_t * env);
+
+#endif
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You 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_UG_ECHO_UTIL_H
+#define AXIS2_UG_ECHO_UTIL_H
+
+#include <stdio.h>
+#include <axiom.h>
+
+axiom_node_t* build_om_payload_for_echo_svc (const axutil_env_t * env);
+
+#endif

Modified: axis/axis2/c/core/trunk/samples/client/amqp/mtom/mtom_client.c
URL: http://svn.apache.org/viewvc/axis/axis2/c/core/trunk/samples/client/amqp/mtom/mtom_client.c?rev=958884&r1=958883&r2=958884&view=diff
==============================================================================
--- axis/axis2/c/core/trunk/samples/client/amqp/mtom/mtom_client.c (original)
+++ axis/axis2/c/core/trunk/samples/client/amqp/mtom/mtom_client.c Tue Jun 29 08:57:05 2010
@@ -1,259 +1,259 @@
-
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You 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.
- */
-
-#include <stdio.h>
-#include <axiom.h>
-#include <axis2_util.h>
-#include <axiom_soap.h>
-#include <axis2_client.h>
-
-axiom_node_t *build_om_programatically(
-    const axutil_env_t * env,
-    const axis2_char_t * image_name,
-    const axis2_char_t * to_save_name,
-    axis2_bool_t optimized);
-
-int 
-process_response_node(
-    const axutil_env_t * env,
-    axiom_node_t *node,
-    const axis2_char_t * to_save_name);
-
-
-int
-main(
-    int argc,
-    char **argv)
-{
-    const axutil_env_t *env = NULL;
-    const axis2_char_t *address = NULL;
-    axis2_endpoint_ref_t *endpoint_ref = NULL;
-    axis2_options_t *options = NULL;
-    const axis2_char_t *client_home = NULL;
-    axis2_svc_client_t *svc_client = NULL;
-    axiom_node_t *payload = NULL;
-    axiom_node_t *ret_node = NULL;
-    const axis2_char_t *image_name = "resources/axis2.jpg";
-    const axis2_char_t *to_save_name = "test.jpg";
-    axis2_bool_t optimized = AXIS2_TRUE;
-
-    /* Set up the environment */
-    env = axutil_env_create_all("mtom_amqp.log", AXIS2_LOG_LEVEL_TRACE);
-
-    /* Set end point reference of mtom service */
-    address = "amqp://localhost:5672/axis2/services/mtom";
-    if (argc > 1)
-        address = argv[1];
-    if (axutil_strcmp(address, "-h") == 0)
-    {
-        printf
-            ("Usage : %s [endpoint_url] [image_name] [to_save_name] [do_not_optimize]\n",
-             argv[0]);
-        printf("use -h for help\n");
-        return 0;
-    }
-    if (argc > 2)
-        image_name = argv[2];
-    if (argc > 3)
-        to_save_name = argv[3];
-    if (argc > 4)
-        optimized = AXIS2_FALSE;
-
-    printf("Using endpoint : %s\n", address);
-
-    /* Create EPR with given address */
-    endpoint_ref = axis2_endpoint_ref_create(env, address);
-
-    /* Setup options */
-    options = axis2_options_create(env);
-    axis2_options_set_to(options, env, endpoint_ref);
-    axis2_options_set_action(options, env,
-                             "http://ws.apache.org/axis2/c/samples/mtomSample");
-
-    axis2_options_set_soap_version(options, env, AXIOM_SOAP11);
-
-    if(optimized)
-    {
-        axis2_options_set_enable_mtom(options, env, AXIS2_TRUE);
-    }
-
-    /* Set up deploy folder. It is from the deploy folder, the configuration is picked up
-     * using the axis2.xml file.
-     * In this sample client_home points to the Axis2/C default deploy folder. The client_home can 
-     * be different from this folder on your system. For example, you may have a different folder 
-     * (say, my_client_folder) with its own axis2.xml file. my_client_folder/modules will have the 
-     * modules that the client uses
-     */
-    client_home = AXIS2_GETENV("AXIS2C_HOME");
-    if (!client_home || !strcmp(client_home, ""))
-        client_home = "../..";
-
-    /* Create service client */
-    svc_client = axis2_svc_client_create(env, client_home);
-    if (!svc_client)
-    {
-        printf
-            ("Error creating service client, Please check AXIS2C_HOME again\n");
-        AXIS2_LOG_ERROR(env->log, AXIS2_LOG_SI,
-                        "Stub invoke FAILED: Error code:" " %d :: %s",
-                        env->error->error_number,
-                        AXIS2_ERROR_GET_MESSAGE(env->error));
-        return -1;
-    }
-
-    /* Set service client options */
-    axis2_svc_client_set_options(svc_client, env, options);
-
-    /* Engage addressing module */
-    axis2_svc_client_engage_module(svc_client, env, AXIS2_MODULE_ADDRESSING);
-
-    /* Build the SOAP request message payload using OM API. */
-    payload =
-        build_om_programatically(env, image_name, to_save_name, optimized);
-
-    /* Send request */
-    ret_node = axis2_svc_client_send_receive(svc_client, env, payload);
-    if (ret_node)
-    {
-        axis2_char_t *om_str = NULL;
-        om_str = axiom_node_to_string(ret_node, env);
-        if (om_str)
-        {
-            if (axis2_svc_client_get_last_response_has_fault(svc_client, env) == AXIS2_TRUE)
-            {
-                printf("\nRecieved Fault : %s\n", om_str);
-                AXIS2_FREE(env->allocator, om_str);
-            }
-            else
-            {
-                printf("\nReceived OM : %s\n", om_str);
-                AXIS2_FREE(env->allocator, om_str);
-                printf("\nmtom client invoke SUCCESSFUL!\n");
-                process_response_node(env, ret_node, to_save_name);
-            }
-        }
-    }
-    else
-    {
-        AXIS2_LOG_ERROR(env->log, AXIS2_LOG_SI,
-                        "Stub invoke FAILED: Error code:" " %d :: %s",
-                        env->error->error_number,
-                        AXIS2_ERROR_GET_MESSAGE(env->error));
-        printf("\nmtom client invoke FAILED!\n");
-    }
-
-    if (svc_client)
-    {
-        axis2_svc_client_free(svc_client, env);
-        svc_client = NULL;
-    }
-
-    if (env)
-    {
-        axutil_env_free((axutil_env_t *) env);
-        env = NULL;
-    }
-
-    return 0;
-
-}
-
-/* build SOAP request message content using OM */
-axiom_node_t *
-build_om_programatically(
-    const axutil_env_t * env,
-    const axis2_char_t * image_name,
-    const axis2_char_t * to_save_name,
-    axis2_bool_t optimized)
-{
-    axiom_node_t *mtom_om_node = NULL;
-    axiom_element_t *mtom_om_ele = NULL;
-    axiom_node_t *image_om_node = NULL;
-    axiom_element_t *image_om_ele = NULL;
-    axiom_node_t *file_om_node = NULL;
-    axiom_element_t *file_om_ele = NULL;
-    axiom_node_t *data_om_node = NULL;
-    axiom_text_t *data_text = NULL;
-    axiom_namespace_t *ns1 = NULL;
-    axis2_char_t *om_str = NULL;
-
-    axiom_data_handler_t *data_handler = NULL;
-
-    ns1 =
-        axiom_namespace_create(env, "http://ws.apache.org/axis2/c/samples/mtom",
-                               "ns1");
-    mtom_om_ele =
-        axiom_element_create(env, NULL, "mtomSample", ns1, &mtom_om_node);
-
-    file_om_ele =
-        axiom_element_create(env, mtom_om_node, "fileName", ns1, &file_om_node);
-    axiom_element_set_text(file_om_ele, env, to_save_name, file_om_node);
-
-    image_om_ele =
-        axiom_element_create(env, mtom_om_node, "image", ns1, &image_om_node);
-
-    data_handler = axiom_data_handler_create(env, image_name, "image/jpeg");
-    data_text =
-        axiom_text_create_with_data_handler(env, image_om_node, data_handler,
-                                            &data_om_node);
-    axiom_text_set_optimize(data_text, env, optimized);
-    om_str = axiom_node_to_string(mtom_om_node, env);
-    if (om_str)
-    {
-        printf("%s", om_str);
-        AXIS2_FREE(env->allocator, om_str);
-    }
-    return mtom_om_node;
-}
-
-
-int 
-process_response_node(
-    const axutil_env_t * env,
-    axiom_node_t *node,
-    const axis2_char_t * to_save_name)
-{
-    axiom_node_t *res_om_node = NULL;
-    axiom_element_t *res_om_ele = NULL;
-    res_om_node = axiom_node_get_first_child(node, env);
-
-    if(axiom_node_get_node_type(res_om_node, env) == AXIOM_TEXT)
-    {/** received mtom atttachment */
-        axiom_data_handler_t *data_handler = NULL;
-        axiom_text_t *axiom_text = (axiom_text_t*)axiom_node_get_data_element(res_om_node, env);
-        data_handler = axiom_text_get_data_handler(axiom_text, env);
-
-        /*axiom_data_handler_set_file_name(data_handler, env, (axis2_char_t *)to_save_name);*/
-        if(axiom_data_handler_get_cached(data_handler, env)) 
-        {
-            printf("Attachment is cached.\n");    
-        }   
-        else
-        {
-            axiom_data_handler_set_file_name(data_handler, env, "test");
-            axiom_data_handler_write_to(data_handler, env);
-        }
-    }else if(axiom_node_get_node_type(res_om_node, env) == AXIOM_ELEMENT){
-        res_om_ele = axiom_node_get_data_element(res_om_node, env);
-        printf("Base64 String received \n\n\n %s \n\n", axiom_element_get_text(res_om_ele, env, res_om_node));
-    }
-
-    return 0;
-}
-
-
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You 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.
+ */
+
+#include <stdio.h>
+#include <axiom.h>
+#include <axis2_util.h>
+#include <axiom_soap.h>
+#include <axis2_client.h>
+
+axiom_node_t *build_om_programatically(
+    const axutil_env_t * env,
+    const axis2_char_t * image_name,
+    const axis2_char_t * to_save_name,
+    axis2_bool_t optimized);
+
+int 
+process_response_node(
+    const axutil_env_t * env,
+    axiom_node_t *node,
+    const axis2_char_t * to_save_name);
+
+
+int
+main(
+    int argc,
+    char **argv)
+{
+    const axutil_env_t *env = NULL;
+    const axis2_char_t *address = NULL;
+    axis2_endpoint_ref_t *endpoint_ref = NULL;
+    axis2_options_t *options = NULL;
+    const axis2_char_t *client_home = NULL;
+    axis2_svc_client_t *svc_client = NULL;
+    axiom_node_t *payload = NULL;
+    axiom_node_t *ret_node = NULL;
+    const axis2_char_t *image_name = "resources/axis2.jpg";
+    const axis2_char_t *to_save_name = "test.jpg";
+    axis2_bool_t optimized = AXIS2_TRUE;
+
+    /* Set up the environment */
+    env = axutil_env_create_all("mtom_amqp.log", AXIS2_LOG_LEVEL_TRACE);
+
+    /* Set end point reference of mtom service */
+    address = "amqp://localhost:5672/axis2/services/mtom";
+    if (argc > 1)
+        address = argv[1];
+    if (axutil_strcmp(address, "-h") == 0)
+    {
+        printf
+            ("Usage : %s [endpoint_url] [image_name] [to_save_name] [do_not_optimize]\n",
+             argv[0]);
+        printf("use -h for help\n");
+        return 0;
+    }
+    if (argc > 2)
+        image_name = argv[2];
+    if (argc > 3)
+        to_save_name = argv[3];
+    if (argc > 4)
+        optimized = AXIS2_FALSE;
+
+    printf("Using endpoint : %s\n", address);
+
+    /* Create EPR with given address */
+    endpoint_ref = axis2_endpoint_ref_create(env, address);
+
+    /* Setup options */
+    options = axis2_options_create(env);
+    axis2_options_set_to(options, env, endpoint_ref);
+    axis2_options_set_action(options, env,
+                             "http://ws.apache.org/axis2/c/samples/mtomSample");
+
+    axis2_options_set_soap_version(options, env, AXIOM_SOAP11);
+
+    if(optimized)
+    {
+        axis2_options_set_enable_mtom(options, env, AXIS2_TRUE);
+    }
+
+    /* Set up deploy folder. It is from the deploy folder, the configuration is picked up
+     * using the axis2.xml file.
+     * In this sample client_home points to the Axis2/C default deploy folder. The client_home can 
+     * be different from this folder on your system. For example, you may have a different folder 
+     * (say, my_client_folder) with its own axis2.xml file. my_client_folder/modules will have the 
+     * modules that the client uses
+     */
+    client_home = AXIS2_GETENV("AXIS2C_HOME");
+    if (!client_home || !strcmp(client_home, ""))
+        client_home = "../..";
+
+    /* Create service client */
+    svc_client = axis2_svc_client_create(env, client_home);
+    if (!svc_client)
+    {
+        printf
+            ("Error creating service client, Please check AXIS2C_HOME again\n");
+        AXIS2_LOG_ERROR(env->log, AXIS2_LOG_SI,
+                        "Stub invoke FAILED: Error code:" " %d :: %s",
+                        env->error->error_number,
+                        AXIS2_ERROR_GET_MESSAGE(env->error));
+        return -1;
+    }
+
+    /* Set service client options */
+    axis2_svc_client_set_options(svc_client, env, options);
+
+    /* Engage addressing module */
+    axis2_svc_client_engage_module(svc_client, env, AXIS2_MODULE_ADDRESSING);
+
+    /* Build the SOAP request message payload using OM API. */
+    payload =
+        build_om_programatically(env, image_name, to_save_name, optimized);
+
+    /* Send request */
+    ret_node = axis2_svc_client_send_receive(svc_client, env, payload);
+    if (ret_node)
+    {
+        axis2_char_t *om_str = NULL;
+        om_str = axiom_node_to_string(ret_node, env);
+        if (om_str)
+        {
+            if (axis2_svc_client_get_last_response_has_fault(svc_client, env) == AXIS2_TRUE)
+            {
+                printf("\nRecieved Fault : %s\n", om_str);
+                AXIS2_FREE(env->allocator, om_str);
+            }
+            else
+            {
+                printf("\nReceived OM : %s\n", om_str);
+                AXIS2_FREE(env->allocator, om_str);
+                printf("\nmtom client invoke SUCCESSFUL!\n");
+                process_response_node(env, ret_node, to_save_name);
+            }
+        }
+    }
+    else
+    {
+        AXIS2_LOG_ERROR(env->log, AXIS2_LOG_SI,
+                        "Stub invoke FAILED: Error code:" " %d :: %s",
+                        env->error->error_number,
+                        AXIS2_ERROR_GET_MESSAGE(env->error));
+        printf("\nmtom client invoke FAILED!\n");
+    }
+
+    if (svc_client)
+    {
+        axis2_svc_client_free(svc_client, env);
+        svc_client = NULL;
+    }
+
+    if (env)
+    {
+        axutil_env_free((axutil_env_t *) env);
+        env = NULL;
+    }
+
+    return 0;
+
+}
+
+/* build SOAP request message content using OM */
+axiom_node_t *
+build_om_programatically(
+    const axutil_env_t * env,
+    const axis2_char_t * image_name,
+    const axis2_char_t * to_save_name,
+    axis2_bool_t optimized)
+{
+    axiom_node_t *mtom_om_node = NULL;
+    axiom_element_t *mtom_om_ele = NULL;
+    axiom_node_t *image_om_node = NULL;
+    axiom_element_t *image_om_ele = NULL;
+    axiom_node_t *file_om_node = NULL;
+    axiom_element_t *file_om_ele = NULL;
+    axiom_node_t *data_om_node = NULL;
+    axiom_text_t *data_text = NULL;
+    axiom_namespace_t *ns1 = NULL;
+    axis2_char_t *om_str = NULL;
+
+    axiom_data_handler_t *data_handler = NULL;
+
+    ns1 =
+        axiom_namespace_create(env, "http://ws.apache.org/axis2/c/samples/mtom",
+                               "ns1");
+    mtom_om_ele =
+        axiom_element_create(env, NULL, "mtomSample", ns1, &mtom_om_node);
+
+    file_om_ele =
+        axiom_element_create(env, mtom_om_node, "fileName", ns1, &file_om_node);
+    axiom_element_set_text(file_om_ele, env, to_save_name, file_om_node);
+
+    image_om_ele =
+        axiom_element_create(env, mtom_om_node, "image", ns1, &image_om_node);
+
+    data_handler = axiom_data_handler_create(env, image_name, "image/jpeg");
+    data_text =
+        axiom_text_create_with_data_handler(env, image_om_node, data_handler,
+                                            &data_om_node);
+    axiom_text_set_optimize(data_text, env, optimized);
+    om_str = axiom_node_to_string(mtom_om_node, env);
+    if (om_str)
+    {
+        printf("%s", om_str);
+        AXIS2_FREE(env->allocator, om_str);
+    }
+    return mtom_om_node;
+}
+
+
+int 
+process_response_node(
+    const axutil_env_t * env,
+    axiom_node_t *node,
+    const axis2_char_t * to_save_name)
+{
+    axiom_node_t *res_om_node = NULL;
+    axiom_element_t *res_om_ele = NULL;
+    res_om_node = axiom_node_get_first_child(node, env);
+
+    if(axiom_node_get_node_type(res_om_node, env) == AXIOM_TEXT)
+    {/** received mtom atttachment */
+        axiom_data_handler_t *data_handler = NULL;
+        axiom_text_t *axiom_text = (axiom_text_t*)axiom_node_get_data_element(res_om_node, env);
+        data_handler = axiom_text_get_data_handler(axiom_text, env);
+
+        /*axiom_data_handler_set_file_name(data_handler, env, (axis2_char_t *)to_save_name);*/
+        if(axiom_data_handler_get_cached(data_handler, env)) 
+        {
+            printf("Attachment is cached.\n");    
+        }   
+        else
+        {
+            axiom_data_handler_set_file_name(data_handler, env, "test");
+            axiom_data_handler_write_to(data_handler, env);
+        }
+    }else if(axiom_node_get_node_type(res_om_node, env) == AXIOM_ELEMENT){
+        res_om_ele = axiom_node_get_data_element(res_om_node, env);
+        printf("Base64 String received \n\n\n %s \n\n", axiom_element_get_text(res_om_ele, env, res_om_node));
+    }
+
+    return 0;
+}
+
+

Modified: axis/axis2/c/core/trunk/samples/client/amqp/notify/notify_client.c
URL: http://svn.apache.org/viewvc/axis/axis2/c/core/trunk/samples/client/amqp/notify/notify_client.c?rev=958884&r1=958883&r2=958884&view=diff
==============================================================================
--- axis/axis2/c/core/trunk/samples/client/amqp/notify/notify_client.c (original)
+++ axis/axis2/c/core/trunk/samples/client/amqp/notify/notify_client.c Tue Jun 29 08:57:05 2010
@@ -1,152 +1,152 @@
-
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You 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.
- */
-
-#include <stdio.h>
-#include <axiom.h>
-#include <axis2_util.h>
-#include <axiom_soap.h>
-#include <axis2_client.h>
-
-axiom_node_t *build_om_programatically(
-    const axutil_env_t * env);
-
-int
-main(
-    int argc,
-    char **argv)
-{
-    const axutil_env_t *env = NULL;
-    const axis2_char_t *address = NULL;
-    axis2_endpoint_ref_t *endpoint_ref = NULL;
-    axis2_options_t *options = NULL;
-    const axis2_char_t *client_home = NULL;
-    axis2_svc_client_t *svc_client = NULL;
-    axiom_node_t *payload = NULL;
-    axis2_status_t status = AXIS2_FAILURE;
-
-    /* Set up the environment */
-    env = axutil_env_create_all("notify_amqp.log", AXIS2_LOG_LEVEL_TRACE);
-
-    /* Set end point reference of echo service */
-    address = "amqp://localhost:5672/axis2/services/notify";
-    if (argc > 1)
-        address = argv[1];
-    if (axutil_strcmp(address, "-h") == 0)
-    {
-        printf("Usage : %s [endpoint_url]\n", argv[0]);
-        printf("use -h for help\n");
-        return 0;
-    }
-    printf("Using endpoint : %s\n", address);
-
-    /* Create EPR with given address */
-    endpoint_ref = axis2_endpoint_ref_create(env, address);
-
-    /* Setup options */
-    options = axis2_options_create(env);
-    axis2_options_set_to(options, env, endpoint_ref);
-    axis2_options_set_action(options, env, "http://example.org/action/notify");
-
-    /* Set up deploy folder. It is from the deploy folder, the configuration is picked up
-     * using the axis2.xml file.
-     * In this sample client_home points to the Axis2/C default deploy folder. The client_home can 
-     * be different from this folder on your system. For example, you may have a different folder 
-     * (say, my_client_folder) with its own axis2.xml file. my_client_folder/modules will have the 
-     * modules that the client uses
-     */
-    client_home = AXIS2_GETENV("AXIS2C_HOME");
-    if (!client_home || !strcmp(client_home, ""))
-        client_home = "../..";
-
-    /* Create service client */
-    svc_client = axis2_svc_client_create(env, client_home);
-    if (!svc_client)
-    {
-        printf
-            ("Error creating service client, Please check AXIS2C_HOME again\n");
-        AXIS2_LOG_ERROR(env->log, AXIS2_LOG_SI,
-                        "Stub invoke FAILED: Error code:" " %d :: %s",
-                        env->error->error_number,
-                        AXIS2_ERROR_GET_MESSAGE(env->error));
-        return -1;
-    }
-
-    /* Set service client options */
-    axis2_svc_client_set_options(svc_client, env, options);
-
-    /* Engage addressing module */
-    axis2_svc_client_engage_module(svc_client, env, AXIS2_MODULE_ADDRESSING);
-
-    /* Build the SOAP request message payload using OM API. */
-    payload = build_om_programatically(env);
-
-    /* Send request */
-    status = axis2_svc_client_send_robust(svc_client, env, payload);
-
-    if (status == AXIS2_SUCCESS)
-    {
-        printf("\nnotify client invoke SUCCESSFUL!\n");
-    }
-    else
-    {
-        AXIS2_LOG_ERROR(env->log, AXIS2_LOG_SI,
-                        "Stub invoke FAILED: Error code:" " %d :: %s",
-                        env->error->error_number,
-                        AXIS2_ERROR_GET_MESSAGE(env->error));
-        printf("notify client invoke FAILED!\n");
-    }
-
-    if (svc_client)
-    {
-        axis2_svc_client_free(svc_client, env);
-        svc_client = NULL;
-    }
-
-    if (env)
-    {
-        axutil_env_free((axutil_env_t *) env);
-        env = NULL;
-    }
-
-    return 0;
-}
-
-/* build SOAP request message content using OM */
-axiom_node_t *
-build_om_programatically(
-    const axutil_env_t * env)
-{
-    axiom_node_t *notify_om_node = NULL;
-    axiom_element_t *notify_om_ele = NULL;
-    axiom_namespace_t *ns1 = NULL;
-    axis2_char_t *buffer = NULL;
-
-    ns1 = axiom_namespace_create(env, "http://example.org/notify", "m");
-    notify_om_ele =
-        axiom_element_create(env, NULL, "notify", ns1, &notify_om_node);
-    axiom_element_set_text(notify_om_ele, env, "notify5", notify_om_node);
-
-    buffer = axiom_node_to_string(notify_om_node, env);
-    if (buffer)
-    {
-        printf("\nSending OM node in XML : %s \n", buffer);
-        AXIS2_FREE(env->allocator, buffer);
-    }
-
-    return notify_om_node;
-}
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You 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.
+ */
+
+#include <stdio.h>
+#include <axiom.h>
+#include <axis2_util.h>
+#include <axiom_soap.h>
+#include <axis2_client.h>
+
+axiom_node_t *build_om_programatically(
+    const axutil_env_t * env);
+
+int
+main(
+    int argc,
+    char **argv)
+{
+    const axutil_env_t *env = NULL;
+    const axis2_char_t *address = NULL;
+    axis2_endpoint_ref_t *endpoint_ref = NULL;
+    axis2_options_t *options = NULL;
+    const axis2_char_t *client_home = NULL;
+    axis2_svc_client_t *svc_client = NULL;
+    axiom_node_t *payload = NULL;
+    axis2_status_t status = AXIS2_FAILURE;
+
+    /* Set up the environment */
+    env = axutil_env_create_all("notify_amqp.log", AXIS2_LOG_LEVEL_TRACE);
+
+    /* Set end point reference of echo service */
+    address = "amqp://localhost:5672/axis2/services/notify";
+    if (argc > 1)
+        address = argv[1];
+    if (axutil_strcmp(address, "-h") == 0)
+    {
+        printf("Usage : %s [endpoint_url]\n", argv[0]);
+        printf("use -h for help\n");
+        return 0;
+    }
+    printf("Using endpoint : %s\n", address);
+
+    /* Create EPR with given address */
+    endpoint_ref = axis2_endpoint_ref_create(env, address);
+
+    /* Setup options */
+    options = axis2_options_create(env);
+    axis2_options_set_to(options, env, endpoint_ref);
+    axis2_options_set_action(options, env, "http://example.org/action/notify");
+
+    /* Set up deploy folder. It is from the deploy folder, the configuration is picked up
+     * using the axis2.xml file.
+     * In this sample client_home points to the Axis2/C default deploy folder. The client_home can 
+     * be different from this folder on your system. For example, you may have a different folder 
+     * (say, my_client_folder) with its own axis2.xml file. my_client_folder/modules will have the 
+     * modules that the client uses
+     */
+    client_home = AXIS2_GETENV("AXIS2C_HOME");
+    if (!client_home || !strcmp(client_home, ""))
+        client_home = "../..";
+
+    /* Create service client */
+    svc_client = axis2_svc_client_create(env, client_home);
+    if (!svc_client)
+    {
+        printf
+            ("Error creating service client, Please check AXIS2C_HOME again\n");
+        AXIS2_LOG_ERROR(env->log, AXIS2_LOG_SI,
+                        "Stub invoke FAILED: Error code:" " %d :: %s",
+                        env->error->error_number,
+                        AXIS2_ERROR_GET_MESSAGE(env->error));
+        return -1;
+    }
+
+    /* Set service client options */
+    axis2_svc_client_set_options(svc_client, env, options);
+
+    /* Engage addressing module */
+    axis2_svc_client_engage_module(svc_client, env, AXIS2_MODULE_ADDRESSING);
+
+    /* Build the SOAP request message payload using OM API. */
+    payload = build_om_programatically(env);
+
+    /* Send request */
+    status = axis2_svc_client_send_robust(svc_client, env, payload);
+
+    if (status == AXIS2_SUCCESS)
+    {
+        printf("\nnotify client invoke SUCCESSFUL!\n");
+    }
+    else
+    {
+        AXIS2_LOG_ERROR(env->log, AXIS2_LOG_SI,
+                        "Stub invoke FAILED: Error code:" " %d :: %s",
+                        env->error->error_number,
+                        AXIS2_ERROR_GET_MESSAGE(env->error));
+        printf("notify client invoke FAILED!\n");
+    }
+
+    if (svc_client)
+    {
+        axis2_svc_client_free(svc_client, env);
+        svc_client = NULL;
+    }
+
+    if (env)
+    {
+        axutil_env_free((axutil_env_t *) env);
+        env = NULL;
+    }
+
+    return 0;
+}
+
+/* build SOAP request message content using OM */
+axiom_node_t *
+build_om_programatically(
+    const axutil_env_t * env)
+{
+    axiom_node_t *notify_om_node = NULL;
+    axiom_element_t *notify_om_ele = NULL;
+    axiom_namespace_t *ns1 = NULL;
+    axis2_char_t *buffer = NULL;
+
+    ns1 = axiom_namespace_create(env, "http://example.org/notify", "m");
+    notify_om_ele =
+        axiom_element_create(env, NULL, "notify", ns1, &notify_om_node);
+    axiom_element_set_text(notify_om_ele, env, "notify5", notify_om_node);
+
+    buffer = axiom_node_to_string(notify_om_node, env);
+    if (buffer)
+    {
+        printf("\nSending OM node in XML : %s \n", buffer);
+        AXIS2_FREE(env->allocator, buffer);
+    }
+
+    return notify_om_node;
+}

Modified: axis/axis2/c/core/trunk/src/core/deployment/conf_init.c
URL: http://svn.apache.org/viewvc/axis/axis2/c/core/trunk/src/core/deployment/conf_init.c?rev=958884&r1=958883&r2=958884&view=diff
==============================================================================
--- axis/axis2/c/core/trunk/src/core/deployment/conf_init.c (original)
+++ axis/axis2/c/core/trunk/src/core/deployment/conf_init.c Tue Jun 29 08:57:05 2010
@@ -333,30 +333,30 @@ axis2_load_services(
             {
                 continue;
             }
-			impl_class = axis2_svc_get_impl_class(svc, env);
-			if(impl_class)
+			impl_class = axis2_svc_get_impl_class(svc, env);
+			if(impl_class)
 				continue;
 
-			ops_hash = axis2_svc_get_all_ops(svc, env);
-			if(ops_hash)
-			{
-				axutil_hash_index_t *op_hi = NULL;
-				void *op = NULL;
-				op_hi = axutil_hash_first(ops_hash, env);
-				if(op_hi)
-				{
-					axutil_hash_this(op_hi, NULL, NULL, &op);
-					if(op)
-					{
-						msg_recv = axis2_op_get_msg_recv(op, env);
-						if(msg_recv)
-						{
-							axis2_msg_recv_set_conf_ctx(msg_recv, env, conf_ctx);
-							axis2_msg_recv_load_and_init_svc(msg_recv, env, svc);
-						}
-					}
-				}
-
+			ops_hash = axis2_svc_get_all_ops(svc, env);
+			if(ops_hash)
+			{
+				axutil_hash_index_t *op_hi = NULL;
+				void *op = NULL;
+				op_hi = axutil_hash_first(ops_hash, env);
+				if(op_hi)
+				{
+					axutil_hash_this(op_hi, NULL, NULL, &op);
+					if(op)
+					{
+						msg_recv = axis2_op_get_msg_recv(op, env);
+						if(msg_recv)
+						{
+							axis2_msg_recv_set_conf_ctx(msg_recv, env, conf_ctx);
+							axis2_msg_recv_load_and_init_svc(msg_recv, env, svc);
+						}
+					}
+				}
+
 			}
 			/*
             svc_desc = (axis2_svc_t *)svc;

Modified: axis/axis2/c/core/trunk/src/core/transport/amqp/receiver/axis2_amqp_receiver.c
URL: http://svn.apache.org/viewvc/axis/axis2/c/core/trunk/src/core/transport/amqp/receiver/axis2_amqp_receiver.c?rev=958884&r1=958883&r2=958884&view=diff
==============================================================================
--- axis/axis2/c/core/trunk/src/core/transport/amqp/receiver/axis2_amqp_receiver.c (original)
+++ axis/axis2/c/core/trunk/src/core/transport/amqp/receiver/axis2_amqp_receiver.c Tue Jun 29 08:57:05 2010
@@ -1,275 +1,275 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You 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.
- */
-
-#include <axis2_amqp_util.h>
-#include <axis2_amqp_defines.h>
-#include <axis2_amqp_receiver.h>
-
-static const axis2_transport_receiver_ops_t amqp_receiver_ops =
-{
-    axis2_amqp_receiver_init,
-    axis2_amqp_receiver_start,
-    axis2_amqp_receiver_get_reply_to_epr,
-    axis2_amqp_receiver_get_conf_ctx,
-    axis2_amqp_receiver_is_running,
-    axis2_amqp_receiver_stop,
-    axis2_amqp_receiver_free
-};
-
-AXIS2_EXTERN axis2_transport_receiver_t* AXIS2_CALL
-axis2_amqp_receiver_create(
-    const axutil_env_t* env,
-    const axis2_char_t* repo,
-    const axis2_char_t* qpid_broker_ip,
-    int qpid_broker_port)
-{
-    AXIS2_ENV_CHECK(env, NULL);
-
-    axis2_amqp_receiver_resource_pack_t* receiver_resource_pack = NULL;
-
-    receiver_resource_pack = (axis2_amqp_receiver_resource_pack_t*)AXIS2_MALLOC(env->allocator,
-        sizeof(axis2_amqp_receiver_resource_pack_t));
-
-    if(!receiver_resource_pack)
-    {
-        AXIS2_ERROR_SET(env->error, AXIS2_ERROR_NO_MEMORY, AXIS2_FAILURE);
-        return NULL;
-    }
-
-    receiver_resource_pack->receiver.ops = &amqp_receiver_ops;
-    receiver_resource_pack->qpid_receiver = NULL;
-    receiver_resource_pack->conf_ctx = NULL;
-    receiver_resource_pack->conf_ctx_private = NULL;
-
-    if(repo)
-    {
-        /**
-         * 1. We first create a private conf ctx which is owned by this server
-         * 	  we only free this private conf context. We should never free the
-         *    receiver_impl->conf_ctx because it may be owned by any other object which
-         *    may lead to double free.
-         *
-         * 2. The Qpid broker IP and port are set in conf_ctx at two different places.
-         * 	  If the repo is specified, they are set here. Otherwise, they are set
-         * 	  in axis2_amqp_receiver_init method.
-         */
-        axutil_property_t* property = NULL;
-        const axis2_char_t* broker_ip = NULL;
-        int* broker_port = (int*)AXIS2_MALLOC(env->allocator, sizeof(int));
-        *broker_port = AXIS2_QPID_NULL_CONF_INT;
-
-        receiver_resource_pack->conf_ctx_private = axis2_build_conf_ctx(env, repo);
-        if(!receiver_resource_pack->conf_ctx_private)
-        {
-            axis2_amqp_receiver_free((axis2_transport_receiver_t *)receiver_resource_pack, env);
-            return NULL;
-        }
-
-        /* Set broker IP */
-        broker_ip = qpid_broker_ip ? qpid_broker_ip : AXIS2_QPID_DEFAULT_BROKER_IP;
-        property = axutil_property_create_with_args(env, AXIS2_SCOPE_APPLICATION, 0, 0,
-            (void*)broker_ip);
-        axis2_conf_ctx_set_property(receiver_resource_pack->conf_ctx_private, env,
-            AXIS2_AMQP_CONF_CTX_PROPERTY_BROKER_IP, property);
-
-        /* Set broker port */
-        *broker_port = (qpid_broker_port != AXIS2_QPID_NULL_CONF_INT) ? qpid_broker_port
-            : AXIS2_QPID_DEFAULT_BROKER_PORT;
-        property = axutil_property_create_with_args(env, AXIS2_SCOPE_APPLICATION, 0, 0,
-            (void*)broker_port);
-        axis2_conf_ctx_set_property(receiver_resource_pack->conf_ctx_private, env,
-            AXIS2_AMQP_CONF_CTX_PROPERTY_BROKER_PORT, property);
-
-        receiver_resource_pack->conf_ctx = receiver_resource_pack->conf_ctx_private;
-    }
-
-    return &(receiver_resource_pack->receiver);
-}
-
-AXIS2_EXTERN axis2_status_t AXIS2_CALL
-axis2_amqp_receiver_init(
-    axis2_transport_receiver_t* receiver,
-    const axutil_env_t* env,
-    axis2_conf_ctx_t* conf_ctx,
-    axis2_transport_in_desc_t* in_desc)
-{
-    axis2_amqp_receiver_resource_pack_t* receiver_resource_pack = NULL;
-    axutil_property_t* property = NULL;
-    const axis2_char_t* broker_ip = NULL;
-    int* broker_port = (int*)AXIS2_MALLOC(env->allocator, sizeof(int));
-    *broker_port = AXIS2_QPID_NULL_CONF_INT;
-
-    AXIS2_ENV_CHECK(env, AXIS2_FAILURE);
-
-    receiver_resource_pack = AXIS2_AMQP_RECEIVER_TO_RESOURCE_PACK(receiver);
-    receiver_resource_pack->conf_ctx = conf_ctx;
-
-    /* Set broker IP */
-    broker_ip = axis2_amqp_util_get_in_desc_conf_value_string(in_desc, env,
-        AXIS2_AMQP_CONF_QPID_BROKER_IP);
-    if(!broker_ip)
-    {
-        broker_ip = AXIS2_QPID_DEFAULT_BROKER_IP;
-    }
-    property = axutil_property_create_with_args(env, AXIS2_SCOPE_APPLICATION, 0, 0,
-        (void*)broker_ip);
-    axis2_conf_ctx_set_property(receiver_resource_pack->conf_ctx, env,
-        AXIS2_AMQP_CONF_CTX_PROPERTY_BROKER_IP, property);
-
-    /* Set broker port */
-    *broker_port = axis2_amqp_util_get_in_desc_conf_value_int(in_desc, env,
-        AXIS2_AMQP_CONF_QPID_BROKER_PORT);
-    if(*broker_port == AXIS2_QPID_NULL_CONF_INT)
-    {
-        *broker_port = AXIS2_QPID_DEFAULT_BROKER_PORT;
-    }
-    property = axutil_property_create_with_args(env, AXIS2_SCOPE_APPLICATION, 0, 0,
-        (void*)broker_port);
-    axis2_conf_ctx_set_property(receiver_resource_pack->conf_ctx, env,
-        AXIS2_AMQP_CONF_CTX_PROPERTY_BROKER_PORT, property);
-
-    return AXIS2_SUCCESS;
-}
-
-AXIS2_EXTERN axis2_status_t AXIS2_CALL
-axis2_amqp_receiver_start(
-    axis2_transport_receiver_t* receiver,
-    const axutil_env_t* env)
-{
-    AXIS2_ENV_CHECK(env, AXIS2_FAILURE);
-
-    axis2_status_t status = AXIS2_FAILURE;
-
-    axis2_amqp_receiver_resource_pack_t* amqp_receiver_resource_pack = NULL;
-    axis2_qpid_receiver_resource_pack_t* qpid_receiver_resource_pack = NULL;
-
-    amqp_receiver_resource_pack = AXIS2_AMQP_RECEIVER_TO_RESOURCE_PACK(receiver);
-
-    /* Create Qpid Receiver */
-    qpid_receiver_resource_pack = axis2_qpid_receiver_create(env,
-        amqp_receiver_resource_pack->conf_ctx);
-
-    if(qpid_receiver_resource_pack)
-    {
-        amqp_receiver_resource_pack->qpid_receiver = qpid_receiver_resource_pack;
-
-        status = axis2_qpid_receiver_start(qpid_receiver_resource_pack, env);
-    }
-
-    return status;
-}
-
-AXIS2_EXTERN axis2_endpoint_ref_t* AXIS2_CALL
-axis2_amqp_receiver_get_reply_to_epr(
-    axis2_transport_receiver_t* receiver,
-    const axutil_env_t* env,
-    const axis2_char_t* svc_name)
-{
-    return NULL;
-}
-
-AXIS2_EXTERN axis2_conf_ctx_t* AXIS2_CALL
-axis2_amqp_receiver_get_conf_ctx(
-    axis2_transport_receiver_t* receiver,
-    const axutil_env_t* env)
-{
-    AXIS2_ENV_CHECK(env, NULL);
-
-    return AXIS2_AMQP_RECEIVER_TO_RESOURCE_PACK(receiver)->conf_ctx;
-}
-
-AXIS2_EXTERN axis2_bool_t AXIS2_CALL
-axis2_amqp_receiver_is_running(
-    axis2_transport_receiver_t* receiver,
-    const axutil_env_t* env)
-{
-    return AXIS2_TRUE;
-}
-
-AXIS2_EXTERN axis2_status_t AXIS2_CALL
-axis2_amqp_receiver_stop(
-    axis2_transport_receiver_t* receiver,
-    const axutil_env_t* env)
-{
-    return AXIS2_SUCCESS;
-}
-
-AXIS2_EXTERN void AXIS2_CALL
-axis2_amqp_receiver_free(
-    axis2_transport_receiver_t* receiver,
-    const axutil_env_t* env)
-{
-    AXIS2_ENV_CHECK(env, void);
-
-    axis2_amqp_receiver_resource_pack_t* receiver_resource_pack = NULL;
-    receiver_resource_pack = AXIS2_AMQP_RECEIVER_TO_RESOURCE_PACK(receiver);
-
-    if(receiver_resource_pack->qpid_receiver)
-    {
-        axis2_qpid_receiver_free(receiver_resource_pack->qpid_receiver, env);
-        receiver_resource_pack->qpid_receiver = NULL;
-    }
-
-    if(receiver_resource_pack->conf_ctx_private)
-    {
-        axis2_conf_ctx_free(receiver_resource_pack->conf_ctx_private, env);
-        receiver_resource_pack->conf_ctx_private = NULL;
-    }
-
-    receiver_resource_pack->conf_ctx = NULL; /* Do not free this. It may be owned by some other object */
-
-    AXIS2_FREE(env->allocator, receiver_resource_pack);
-}
-
-/* Library Exports */
-
-AXIS2_EXPORT int
-#ifndef AXIS2_STATIC_DEPLOY
-axis2_get_instance(
-#else
-    axis2_amqp_receiver_get_instance(
-#endif
-    struct axis2_transport_receiver** inst,
-    const axutil_env_t* env)
-{
-    int status = AXIS2_SUCCESS;
-
-    *inst = axis2_amqp_receiver_create(env, NULL, NULL, AXIS2_QPID_NULL_CONF_INT);
-    if(!(*inst))
-    {
-        status = AXIS2_FAILURE;
-    }
-
-    return status;
-}
-
-AXIS2_EXPORT int
-#ifndef AXIS2_STATIC_DEPLOY
-axis2_remove_instance(
-#else
-    axis2_amqp_receiver_remove_instance(
-#endif
-    axis2_transport_receiver_t* inst,
-    const axutil_env_t* env)
-{
-    if(inst)
-    {
-        axis2_transport_receiver_free(inst, env);
-    }
-
-    return AXIS2_SUCCESS;
-}
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You 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.
+ */
+
+#include <axis2_amqp_util.h>
+#include <axis2_amqp_defines.h>
+#include <axis2_amqp_receiver.h>
+
+static const axis2_transport_receiver_ops_t amqp_receiver_ops =
+{
+    axis2_amqp_receiver_init,
+    axis2_amqp_receiver_start,
+    axis2_amqp_receiver_get_reply_to_epr,
+    axis2_amqp_receiver_get_conf_ctx,
+    axis2_amqp_receiver_is_running,
+    axis2_amqp_receiver_stop,
+    axis2_amqp_receiver_free
+};
+
+AXIS2_EXTERN axis2_transport_receiver_t* AXIS2_CALL
+axis2_amqp_receiver_create(
+    const axutil_env_t* env,
+    const axis2_char_t* repo,
+    const axis2_char_t* qpid_broker_ip,
+    int qpid_broker_port)
+{
+    AXIS2_ENV_CHECK(env, NULL);
+
+    axis2_amqp_receiver_resource_pack_t* receiver_resource_pack = NULL;
+
+    receiver_resource_pack = (axis2_amqp_receiver_resource_pack_t*)AXIS2_MALLOC(env->allocator,
+        sizeof(axis2_amqp_receiver_resource_pack_t));
+
+    if(!receiver_resource_pack)
+    {
+        AXIS2_ERROR_SET(env->error, AXIS2_ERROR_NO_MEMORY, AXIS2_FAILURE);
+        return NULL;
+    }
+
+    receiver_resource_pack->receiver.ops = &amqp_receiver_ops;
+    receiver_resource_pack->qpid_receiver = NULL;
+    receiver_resource_pack->conf_ctx = NULL;
+    receiver_resource_pack->conf_ctx_private = NULL;
+
+    if(repo)
+    {
+        /**
+         * 1. We first create a private conf ctx which is owned by this server
+         * 	  we only free this private conf context. We should never free the
+         *    receiver_impl->conf_ctx because it may be owned by any other object which
+         *    may lead to double free.
+         *
+         * 2. The Qpid broker IP and port are set in conf_ctx at two different places.
+         * 	  If the repo is specified, they are set here. Otherwise, they are set
+         * 	  in axis2_amqp_receiver_init method.
+         */
+        axutil_property_t* property = NULL;
+        const axis2_char_t* broker_ip = NULL;
+        int* broker_port = (int*)AXIS2_MALLOC(env->allocator, sizeof(int));
+        *broker_port = AXIS2_QPID_NULL_CONF_INT;
+
+        receiver_resource_pack->conf_ctx_private = axis2_build_conf_ctx(env, repo);
+        if(!receiver_resource_pack->conf_ctx_private)
+        {
+            axis2_amqp_receiver_free((axis2_transport_receiver_t *)receiver_resource_pack, env);
+            return NULL;
+        }
+
+        /* Set broker IP */
+        broker_ip = qpid_broker_ip ? qpid_broker_ip : AXIS2_QPID_DEFAULT_BROKER_IP;
+        property = axutil_property_create_with_args(env, AXIS2_SCOPE_APPLICATION, 0, 0,
+            (void*)broker_ip);
+        axis2_conf_ctx_set_property(receiver_resource_pack->conf_ctx_private, env,
+            AXIS2_AMQP_CONF_CTX_PROPERTY_BROKER_IP, property);
+
+        /* Set broker port */
+        *broker_port = (qpid_broker_port != AXIS2_QPID_NULL_CONF_INT) ? qpid_broker_port
+            : AXIS2_QPID_DEFAULT_BROKER_PORT;
+        property = axutil_property_create_with_args(env, AXIS2_SCOPE_APPLICATION, 0, 0,
+            (void*)broker_port);
+        axis2_conf_ctx_set_property(receiver_resource_pack->conf_ctx_private, env,
+            AXIS2_AMQP_CONF_CTX_PROPERTY_BROKER_PORT, property);
+
+        receiver_resource_pack->conf_ctx = receiver_resource_pack->conf_ctx_private;
+    }
+
+    return &(receiver_resource_pack->receiver);
+}
+
+AXIS2_EXTERN axis2_status_t AXIS2_CALL
+axis2_amqp_receiver_init(
+    axis2_transport_receiver_t* receiver,
+    const axutil_env_t* env,
+    axis2_conf_ctx_t* conf_ctx,
+    axis2_transport_in_desc_t* in_desc)
+{
+    axis2_amqp_receiver_resource_pack_t* receiver_resource_pack = NULL;
+    axutil_property_t* property = NULL;
+    const axis2_char_t* broker_ip = NULL;
+    int* broker_port = (int*)AXIS2_MALLOC(env->allocator, sizeof(int));
+    *broker_port = AXIS2_QPID_NULL_CONF_INT;
+
+    AXIS2_ENV_CHECK(env, AXIS2_FAILURE);
+
+    receiver_resource_pack = AXIS2_AMQP_RECEIVER_TO_RESOURCE_PACK(receiver);
+    receiver_resource_pack->conf_ctx = conf_ctx;
+
+    /* Set broker IP */
+    broker_ip = axis2_amqp_util_get_in_desc_conf_value_string(in_desc, env,
+        AXIS2_AMQP_CONF_QPID_BROKER_IP);
+    if(!broker_ip)
+    {
+        broker_ip = AXIS2_QPID_DEFAULT_BROKER_IP;
+    }
+    property = axutil_property_create_with_args(env, AXIS2_SCOPE_APPLICATION, 0, 0,
+        (void*)broker_ip);
+    axis2_conf_ctx_set_property(receiver_resource_pack->conf_ctx, env,
+        AXIS2_AMQP_CONF_CTX_PROPERTY_BROKER_IP, property);
+
+    /* Set broker port */
+    *broker_port = axis2_amqp_util_get_in_desc_conf_value_int(in_desc, env,
+        AXIS2_AMQP_CONF_QPID_BROKER_PORT);
+    if(*broker_port == AXIS2_QPID_NULL_CONF_INT)
+    {
+        *broker_port = AXIS2_QPID_DEFAULT_BROKER_PORT;
+    }
+    property = axutil_property_create_with_args(env, AXIS2_SCOPE_APPLICATION, 0, 0,
+        (void*)broker_port);
+    axis2_conf_ctx_set_property(receiver_resource_pack->conf_ctx, env,
+        AXIS2_AMQP_CONF_CTX_PROPERTY_BROKER_PORT, property);
+
+    return AXIS2_SUCCESS;
+}
+
+AXIS2_EXTERN axis2_status_t AXIS2_CALL
+axis2_amqp_receiver_start(
+    axis2_transport_receiver_t* receiver,
+    const axutil_env_t* env)
+{
+    AXIS2_ENV_CHECK(env, AXIS2_FAILURE);
+
+    axis2_status_t status = AXIS2_FAILURE;
+
+    axis2_amqp_receiver_resource_pack_t* amqp_receiver_resource_pack = NULL;
+    axis2_qpid_receiver_resource_pack_t* qpid_receiver_resource_pack = NULL;
+
+    amqp_receiver_resource_pack = AXIS2_AMQP_RECEIVER_TO_RESOURCE_PACK(receiver);
+
+    /* Create Qpid Receiver */
+    qpid_receiver_resource_pack = axis2_qpid_receiver_create(env,
+        amqp_receiver_resource_pack->conf_ctx);
+
+    if(qpid_receiver_resource_pack)
+    {
+        amqp_receiver_resource_pack->qpid_receiver = qpid_receiver_resource_pack;
+
+        status = axis2_qpid_receiver_start(qpid_receiver_resource_pack, env);
+    }
+
+    return status;
+}
+
+AXIS2_EXTERN axis2_endpoint_ref_t* AXIS2_CALL
+axis2_amqp_receiver_get_reply_to_epr(
+    axis2_transport_receiver_t* receiver,
+    const axutil_env_t* env,
+    const axis2_char_t* svc_name)
+{
+    return NULL;
+}
+
+AXIS2_EXTERN axis2_conf_ctx_t* AXIS2_CALL
+axis2_amqp_receiver_get_conf_ctx(
+    axis2_transport_receiver_t* receiver,
+    const axutil_env_t* env)
+{
+    AXIS2_ENV_CHECK(env, NULL);
+
+    return AXIS2_AMQP_RECEIVER_TO_RESOURCE_PACK(receiver)->conf_ctx;
+}
+
+AXIS2_EXTERN axis2_bool_t AXIS2_CALL
+axis2_amqp_receiver_is_running(
+    axis2_transport_receiver_t* receiver,
+    const axutil_env_t* env)
+{
+    return AXIS2_TRUE;
+}
+
+AXIS2_EXTERN axis2_status_t AXIS2_CALL
+axis2_amqp_receiver_stop(
+    axis2_transport_receiver_t* receiver,
+    const axutil_env_t* env)
+{
+    return AXIS2_SUCCESS;
+}
+
+AXIS2_EXTERN void AXIS2_CALL
+axis2_amqp_receiver_free(
+    axis2_transport_receiver_t* receiver,
+    const axutil_env_t* env)
+{
+    AXIS2_ENV_CHECK(env, void);
+
+    axis2_amqp_receiver_resource_pack_t* receiver_resource_pack = NULL;
+    receiver_resource_pack = AXIS2_AMQP_RECEIVER_TO_RESOURCE_PACK(receiver);
+
+    if(receiver_resource_pack->qpid_receiver)
+    {
+        axis2_qpid_receiver_free(receiver_resource_pack->qpid_receiver, env);
+        receiver_resource_pack->qpid_receiver = NULL;
+    }
+
+    if(receiver_resource_pack->conf_ctx_private)
+    {
+        axis2_conf_ctx_free(receiver_resource_pack->conf_ctx_private, env);
+        receiver_resource_pack->conf_ctx_private = NULL;
+    }
+
+    receiver_resource_pack->conf_ctx = NULL; /* Do not free this. It may be owned by some other object */
+
+    AXIS2_FREE(env->allocator, receiver_resource_pack);
+}
+
+/* Library Exports */
+
+AXIS2_EXPORT int
+#ifndef AXIS2_STATIC_DEPLOY
+axis2_get_instance(
+#else
+    axis2_amqp_receiver_get_instance(
+#endif
+    struct axis2_transport_receiver** inst,
+    const axutil_env_t* env)
+{
+    int status = AXIS2_SUCCESS;
+
+    *inst = axis2_amqp_receiver_create(env, NULL, NULL, AXIS2_QPID_NULL_CONF_INT);
+    if(!(*inst))
+    {
+        status = AXIS2_FAILURE;
+    }
+
+    return status;
+}
+
+AXIS2_EXPORT int
+#ifndef AXIS2_STATIC_DEPLOY
+axis2_remove_instance(
+#else
+    axis2_amqp_receiver_remove_instance(
+#endif
+    axis2_transport_receiver_t* inst,
+    const axutil_env_t* env)
+{
+    if(inst)
+    {
+        axis2_transport_receiver_free(inst, env);
+    }
+
+    return AXIS2_SUCCESS;
+}

Modified: axis/axis2/c/core/trunk/src/core/transport/amqp/receiver/axis2_amqp_receiver.h
URL: http://svn.apache.org/viewvc/axis/axis2/c/core/trunk/src/core/transport/amqp/receiver/axis2_amqp_receiver.h?rev=958884&r1=958883&r2=958884&view=diff
==============================================================================
--- axis/axis2/c/core/trunk/src/core/transport/amqp/receiver/axis2_amqp_receiver.h (original)
+++ axis/axis2/c/core/trunk/src/core/transport/amqp/receiver/axis2_amqp_receiver.h Tue Jun 29 08:57:05 2010
@@ -1,82 +1,82 @@
-/*
-* Licensed to the Apache Software Foundation (ASF) under one or more
-* contributor license agreements.  See the NOTICE file distributed with
-* this work for additional information regarding copyright ownership.
-* The ASF licenses this file to You 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_AMQP_RECEIVER_H
-#define AXIS2_AMQP_RECEIVER_H
-
-#include <axis2_transport_receiver.h>
-#include <axis2_conf_init.h>
-#include <axis2_qpid_receiver_interface.h>
-
-typedef struct axis2_amqp_receiver_resource_pack
-{
-    axis2_transport_receiver_t  		 receiver;
-	axis2_qpid_receiver_resource_pack_t* qpid_receiver;
-    axis2_conf_ctx_t*           		 conf_ctx;
-    axis2_conf_ctx_t*           		 conf_ctx_private;
-}
-axis2_amqp_receiver_resource_pack_t;
-
-#define AXIS2_AMQP_RECEIVER_TO_RESOURCE_PACK(amqp_receiver) \
-                ((axis2_amqp_receiver_resource_pack_t*)(amqp_receiver))
-
-AXIS2_EXTERN axis2_transport_receiver_t* AXIS2_CALL
-axis2_amqp_receiver_create(
-	const axutil_env_t* env,
-	const axis2_char_t* repo,
-	const axis2_char_t* qpid_broker_ip,
-	int qpid_broker_port);
-
-AXIS2_EXTERN axis2_status_t AXIS2_CALL 
-axis2_amqp_receiver_init(
-	axis2_transport_receiver_t* receiver,
-	const axutil_env_t* env,
-	axis2_conf_ctx_t* conf_ctx,
-	axis2_transport_in_desc_t* in_desc);
-
-AXIS2_EXTERN axis2_status_t AXIS2_CALL 
-axis2_amqp_receiver_start(
-	axis2_transport_receiver_t* receiver,
-	const axutil_env_t* env);
-
-AXIS2_EXTERN axis2_endpoint_ref_t* AXIS2_CALL 
-axis2_amqp_receiver_get_reply_to_epr(
-	axis2_transport_receiver_t* receiver,
-	const axutil_env_t* env,
-	const axis2_char_t* svc_name);
-
-AXIS2_EXTERN axis2_conf_ctx_t* AXIS2_CALL 
-axis2_amqp_receiver_get_conf_ctx(
-	axis2_transport_receiver_t* receiver,
-	const axutil_env_t* env);
-
-AXIS2_EXTERN axis2_bool_t AXIS2_CALL 
-axis2_amqp_receiver_is_running(
-	axis2_transport_receiver_t* receiver,
-	const axutil_env_t* env);
-
-AXIS2_EXTERN axis2_status_t AXIS2_CALL 
-axis2_amqp_receiver_stop(
-	axis2_transport_receiver_t* receiver,
-	const axutil_env_t* env);
-
-AXIS2_EXTERN void AXIS2_CALL 
-axis2_amqp_receiver_free(
-	axis2_transport_receiver_t* receiver,
-	const axutil_env_t* env);
-
-#endif
+/*
+* Licensed to the Apache Software Foundation (ASF) under one or more
+* contributor license agreements.  See the NOTICE file distributed with
+* this work for additional information regarding copyright ownership.
+* The ASF licenses this file to You 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_AMQP_RECEIVER_H
+#define AXIS2_AMQP_RECEIVER_H
+
+#include <axis2_transport_receiver.h>
+#include <axis2_conf_init.h>
+#include <axis2_qpid_receiver_interface.h>
+
+typedef struct axis2_amqp_receiver_resource_pack
+{
+    axis2_transport_receiver_t  		 receiver;
+	axis2_qpid_receiver_resource_pack_t* qpid_receiver;
+    axis2_conf_ctx_t*           		 conf_ctx;
+    axis2_conf_ctx_t*           		 conf_ctx_private;
+}
+axis2_amqp_receiver_resource_pack_t;
+
+#define AXIS2_AMQP_RECEIVER_TO_RESOURCE_PACK(amqp_receiver) \
+                ((axis2_amqp_receiver_resource_pack_t*)(amqp_receiver))
+
+AXIS2_EXTERN axis2_transport_receiver_t* AXIS2_CALL
+axis2_amqp_receiver_create(
+	const axutil_env_t* env,
+	const axis2_char_t* repo,
+	const axis2_char_t* qpid_broker_ip,
+	int qpid_broker_port);
+
+AXIS2_EXTERN axis2_status_t AXIS2_CALL 
+axis2_amqp_receiver_init(
+	axis2_transport_receiver_t* receiver,
+	const axutil_env_t* env,
+	axis2_conf_ctx_t* conf_ctx,
+	axis2_transport_in_desc_t* in_desc);
+
+AXIS2_EXTERN axis2_status_t AXIS2_CALL 
+axis2_amqp_receiver_start(
+	axis2_transport_receiver_t* receiver,
+	const axutil_env_t* env);
+
+AXIS2_EXTERN axis2_endpoint_ref_t* AXIS2_CALL 
+axis2_amqp_receiver_get_reply_to_epr(
+	axis2_transport_receiver_t* receiver,
+	const axutil_env_t* env,
+	const axis2_char_t* svc_name);
+
+AXIS2_EXTERN axis2_conf_ctx_t* AXIS2_CALL 
+axis2_amqp_receiver_get_conf_ctx(
+	axis2_transport_receiver_t* receiver,
+	const axutil_env_t* env);
+
+AXIS2_EXTERN axis2_bool_t AXIS2_CALL 
+axis2_amqp_receiver_is_running(
+	axis2_transport_receiver_t* receiver,
+	const axutil_env_t* env);
+
+AXIS2_EXTERN axis2_status_t AXIS2_CALL 
+axis2_amqp_receiver_stop(
+	axis2_transport_receiver_t* receiver,
+	const axutil_env_t* env);
+
+AXIS2_EXTERN void AXIS2_CALL 
+axis2_amqp_receiver_free(
+	axis2_transport_receiver_t* receiver,
+	const axutil_env_t* env);
+
+#endif

Modified: axis/axis2/c/core/trunk/src/core/transport/amqp/receiver/qpid_receiver/axis2_qpid_receiver.h
URL: http://svn.apache.org/viewvc/axis/axis2/c/core/trunk/src/core/transport/amqp/receiver/qpid_receiver/axis2_qpid_receiver.h?rev=958884&r1=958883&r2=958884&view=diff
==============================================================================
--- axis/axis2/c/core/trunk/src/core/transport/amqp/receiver/qpid_receiver/axis2_qpid_receiver.h (original)
+++ axis/axis2/c/core/trunk/src/core/transport/amqp/receiver/qpid_receiver/axis2_qpid_receiver.h Tue Jun 29 08:57:05 2010
@@ -1,39 +1,39 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You 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
- *
- *      tcp://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_QPID_RECEIVER_H
-#define AXIS2_QPID_RECEIVER_H
-
-#include <axutil_env.h>
-#include <axis2_conf_init.h>
-
-class Axis2QpidReceiver
-{
-	public:
-		Axis2QpidReceiver(const axutil_env_t* env,
-						  axis2_conf_ctx_t* conf_ctx);
-		~Axis2QpidReceiver(void);
-
-		bool start(void);
-		bool shutdown(void);
-
-	private:
-		const axutil_env_t* env;
-		axis2_conf_ctx_t*   conf_ctx;
-};
-
-#endif
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You 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
+ *
+ *      tcp://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_QPID_RECEIVER_H
+#define AXIS2_QPID_RECEIVER_H
+
+#include <axutil_env.h>
+#include <axis2_conf_init.h>
+
+class Axis2QpidReceiver
+{
+	public:
+		Axis2QpidReceiver(const axutil_env_t* env,
+						  axis2_conf_ctx_t* conf_ctx);
+		~Axis2QpidReceiver(void);
+
+		bool start(void);
+		bool shutdown(void);
+
+	private:
+		const axutil_env_t* env;
+		axis2_conf_ctx_t*   conf_ctx;
+};
+
+#endif

Modified: axis/axis2/c/core/trunk/src/core/transport/amqp/receiver/qpid_receiver/axis2_qpid_receiver_interface.h
URL: http://svn.apache.org/viewvc/axis/axis2/c/core/trunk/src/core/transport/amqp/receiver/qpid_receiver/axis2_qpid_receiver_interface.h?rev=958884&r1=958883&r2=958884&view=diff
==============================================================================
--- axis/axis2/c/core/trunk/src/core/transport/amqp/receiver/qpid_receiver/axis2_qpid_receiver_interface.h (original)
+++ axis/axis2/c/core/trunk/src/core/transport/amqp/receiver/qpid_receiver/axis2_qpid_receiver_interface.h Tue Jun 29 08:57:05 2010
@@ -1,58 +1,58 @@
-/*
-* Licensed to the Apache Software Foundation (ASF) under one or more
-* contributor license agreements.  See the NOTICE file distributed with
-* this work for additional information regarding copyright ownership.
-* The ASF licenses this file to You 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_QPID_RECEIVER_INTERFACE_H
-#define AXIS2_QPID_RECEIVER_INTERFACE_H
-
-#include <axis2_util.h>
-#include <axis2_conf_init.h>
-
-#ifdef __cplusplus
-extern "C"
-{
-#endif
-
-	typedef struct axis2_qpid_receiver_resource_pack
-	{
-		void* qpid_receiver;
-	}axis2_qpid_receiver_resource_pack_t;
-
-	AXIS2_EXTERN axis2_qpid_receiver_resource_pack_t* AXIS2_CALL
-	axis2_qpid_receiver_create(
-		const axutil_env_t* env,
-		axis2_conf_ctx_t* conf_ctx);
-
-	AXIS2_EXTERN axis2_status_t AXIS2_CALL
-		axis2_qpid_receiver_start(
-		axis2_qpid_receiver_resource_pack_t* receiver_resource_pack,
-		const axutil_env_t* env);
-
-	AXIS2_EXTERN axis2_bool_t AXIS2_CALL
-		axis2_qpid_receiver_is_running(
-		axis2_qpid_receiver_resource_pack_t* receiver_resource_pack,
-		const axutil_env_t* env);
-
-	AXIS2_EXTERN void AXIS2_CALL
-		axis2_qpid_receiver_free(
-		axis2_qpid_receiver_resource_pack_t* receiver_resource_pack,
-		const axutil_env_t* env);
-
-#ifdef __cplusplus
-}
-#endif
-
-#endif
+/*
+* Licensed to the Apache Software Foundation (ASF) under one or more
+* contributor license agreements.  See the NOTICE file distributed with
+* this work for additional information regarding copyright ownership.
+* The ASF licenses this file to You 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_QPID_RECEIVER_INTERFACE_H
+#define AXIS2_QPID_RECEIVER_INTERFACE_H
+
+#include <axis2_util.h>
+#include <axis2_conf_init.h>
+
+#ifdef __cplusplus
+extern "C"
+{
+#endif
+
+	typedef struct axis2_qpid_receiver_resource_pack
+	{
+		void* qpid_receiver;
+	}axis2_qpid_receiver_resource_pack_t;
+
+	AXIS2_EXTERN axis2_qpid_receiver_resource_pack_t* AXIS2_CALL
+	axis2_qpid_receiver_create(
+		const axutil_env_t* env,
+		axis2_conf_ctx_t* conf_ctx);
+
+	AXIS2_EXTERN axis2_status_t AXIS2_CALL
+		axis2_qpid_receiver_start(
+		axis2_qpid_receiver_resource_pack_t* receiver_resource_pack,
+		const axutil_env_t* env);
+
+	AXIS2_EXTERN axis2_bool_t AXIS2_CALL
+		axis2_qpid_receiver_is_running(
+		axis2_qpid_receiver_resource_pack_t* receiver_resource_pack,
+		const axutil_env_t* env);
+
+	AXIS2_EXTERN void AXIS2_CALL
+		axis2_qpid_receiver_free(
+		axis2_qpid_receiver_resource_pack_t* receiver_resource_pack,
+		const axutil_env_t* env);
+
+#ifdef __cplusplus
+}
+#endif
+
+#endif