You are viewing a plain text version of this content. The canonical link for it is here.
Posted to java-dev@axis.apache.org by na...@apache.org on 2008/12/03 06:31:11 UTC

svn commit: r722784 - in /webservices/axis/trunk/c/src: transport/axis3/ transport/axis3/HTTPChannel/ xml/ xml/xerces/

Author: nadiramra
Date: Tue Dec  2 21:31:11 2008
New Revision: 722784

URL: http://svn.apache.org/viewvc?rev=722784&view=rev
Log:
Minor - remove tabs from code.....replace with spaces.

Modified:
    webservices/axis/trunk/c/src/transport/axis3/ChannelFactory.cpp
    webservices/axis/trunk/c/src/transport/axis3/HTTPChannel/HTTPChannel.cpp
    webservices/axis/trunk/c/src/transport/axis3/HTTPChannel/HTTPChannel.hpp
    webservices/axis/trunk/c/src/transport/axis3/HTTPChannel/HTTPChannelInstantiator.cpp
    webservices/axis/trunk/c/src/transport/axis3/HTTPTransport.cpp
    webservices/axis/trunk/c/src/transport/axis3/HTTPTransport.hpp
    webservices/axis/trunk/c/src/xml/AnyElement.h
    webservices/axis/trunk/c/src/xml/Event.h
    webservices/axis/trunk/c/src/xml/XMLParser.h
    webservices/axis/trunk/c/src/xml/xerces/ParserLoader.cpp
    webservices/axis/trunk/c/src/xml/xerces/SoapBinInputStream.cpp
    webservices/axis/trunk/c/src/xml/xerces/SoapInputSource.cpp
    webservices/axis/trunk/c/src/xml/xerces/XMLParserXerces.cpp
    webservices/axis/trunk/c/src/xml/xerces/XercesHandler.h

Modified: webservices/axis/trunk/c/src/transport/axis3/ChannelFactory.cpp
URL: http://svn.apache.org/viewvc/webservices/axis/trunk/c/src/transport/axis3/ChannelFactory.cpp?rev=722784&r1=722783&r2=722784&view=diff
==============================================================================
--- webservices/axis/trunk/c/src/transport/axis3/ChannelFactory.cpp (original)
+++ webservices/axis/trunk/c/src/transport/axis3/ChannelFactory.cpp Tue Dec  2 21:31:11 2008
@@ -60,7 +60,7 @@
 IChannel * ChannelFactory::
 LoadChannelLibrary( g_ChannelType eChannelType, const char * pcLibraryName)
 {
-	logEntryEngine("ChannelFactory::LoadChannelLibrary")
+    logEntryEngine("ChannelFactory::LoadChannelLibrary")
 
     DLHandler    sLibHandler;
     IChannel *    pChannel = NULL;
@@ -133,7 +133,7 @@
                 m_pChannel[iLibCount] = pChannel;
                 
                 if (AxisTrace::isTransportLoggingEnabled())
-                	pChannel->enableTrace(AxisTrace::getLogFilePath().c_str(), AxisTrace::getLogFilter().c_str());
+                    pChannel->enableTrace(AxisTrace::getLogFilePath().c_str(), AxisTrace::getLogFilter().c_str());
             }
         }
     }
@@ -148,7 +148,7 @@
 bool ChannelFactory::
 UnLoadChannelLibrary( g_ChannelType eChannelType)
 {
-	logEntryEngine("ChannelFactory::UnLoadChannelLibrary")
+    logEntryEngine("ChannelFactory::UnLoadChannelLibrary")
 
     bool    bSuccess = false;
     int        iLibIndex = (int) eChannelType;
@@ -196,14 +196,14 @@
 void ChannelFactory::
 preloadChannels(char *unsecChannel, char *secChannel)
 {
-	if (unsecChannel && strcmp(unsecChannel,"Unknown")) preloadChannel(UnsecureChannel, unsecChannel);
-	if (secChannel && strcmp(secChannel,"Unknown")) preloadChannel(SecureChannel, secChannel);
+    if (unsecChannel && strcmp(unsecChannel,"Unknown")) preloadChannel(UnsecureChannel, unsecChannel);
+    if (secChannel && strcmp(secChannel,"Unknown")) preloadChannel(SecureChannel, secChannel);
 }
 
 void ChannelFactory::
 preloadChannel(g_ChannelType type, const char *pcLibraryName)
 {
-	logEntryEngine("ChannelFactory::preloadChannel")
+    logEntryEngine("ChannelFactory::preloadChannel")
 
     int iLibCount = (int)type;
     ChannelLibrary *pCh = new ChannelLibrary();
@@ -259,7 +259,7 @@
 IChannel *ChannelFactory::
 createChannel(g_ChannelType type) 
 {
-	logEntryEngine("ChannelFactory::createChannel")
+    logEntryEngine("ChannelFactory::createChannel")
 
     int iLibCount = (int)type;
     IChannel *pChannel = NULL;
@@ -269,7 +269,7 @@
         m_pChannel[iLibCount] = pChannel;
         
         if (AxisTrace::isTransportLoggingEnabled())
-        	pChannel->enableTrace(AxisTrace::getLogFilePath().c_str(), AxisTrace::getLogFilter().c_str());
+            pChannel->enableTrace(AxisTrace::getLogFilePath().c_str(), AxisTrace::getLogFilter().c_str());
     }
     
     logExitWithPointer(pChannel)
@@ -280,7 +280,7 @@
 void ChannelFactory::
 unloadChannels()
 {
-	logEntryEngine("ChannelFactory::unloadChannels")
+    logEntryEngine("ChannelFactory::unloadChannels")
 
     for (int i=0; i<(int)MaxChannelCount; i++) 
     {
@@ -291,7 +291,7 @@
             m_ChannelLibrary[i] = NULL;
         }
     }
-	
+    
     logExit()
 }
 

Modified: webservices/axis/trunk/c/src/transport/axis3/HTTPChannel/HTTPChannel.cpp
URL: http://svn.apache.org/viewvc/webservices/axis/trunk/c/src/transport/axis3/HTTPChannel/HTTPChannel.cpp?rev=722784&r1=722783&r2=722784&view=diff
==============================================================================
--- webservices/axis/trunk/c/src/transport/axis3/HTTPChannel/HTTPChannel.cpp (original)
+++ webservices/axis/trunk/c/src/transport/axis3/HTTPChannel/HTTPChannel.cpp Tue Dec  2 21:31:11 2008
@@ -67,7 +67,7 @@
 HTTPChannel::
 ~HTTPChannel()
 {
-	logEntryTransport("HTTPChannel::~HTTPChannel")
+    logEntryTransport("HTTPChannel::~HTTPChannel")
 
     CloseChannel();
     StopSockets();
@@ -100,11 +100,11 @@
 void HTTPChannel::
 setURL( const char * cpURL)
 {
-	logEntryTransport("HTTPChannel::setURL")
+    logEntryTransport("HTTPChannel::setURL")
 
     m_URL.setURL( cpURL);
-	
-	logExit()
+    
+    logExit()
 }
 
 /**
@@ -136,7 +136,7 @@
 bool HTTPChannel::
 open() throw (HTTPTransportException&)
 {
-	logEntryTransport("HTTPChannel::open")
+    logEntryTransport("HTTPChannel::open")
 
     bool    bSuccess = (bool) AXIS_FAIL;
 
@@ -168,12 +168,12 @@
 bool HTTPChannel::
 close()
 {
-	logEntryTransport("HTTPChannel::close")
+    logEntryTransport("HTTPChannel::close")
 
     CloseChannel();
-	
-	logExit()
-	
+    
+    logExit()
+    
     return AXIS_SUCCESS;
 }
 
@@ -209,7 +209,7 @@
 int HTTPChannel::
 readBytes(char *buf, int bufLen)
 {
-	logEntryTransport("HTTPChannel::readBytes")
+    logEntryTransport("HTTPChannel::readBytes")
 
     if (INVALID_SOCKET == m_Sock)
     {
@@ -272,7 +272,7 @@
 
     logDebugBuffer(buf, nByteRecv)
 
-	logExitWithInteger(nByteRecv)
+    logExitWithInteger(nByteRecv)
 
     return nByteRecv;
 }
@@ -291,7 +291,7 @@
 int HTTPChannel::
 writeBytes(const char *buf, int numBytes)
 {
-	logEntryTransport("HTTPChannel::writeBytes")
+    logEntryTransport("HTTPChannel::writeBytes")
 
     logDebugBuffer(buf, numBytes)
 
@@ -323,7 +323,7 @@
         throw HTTPTransportException( SERVER_TRANSPORT_OUTPUT_STREAMING_ERROR, m_LastError.c_str());
     }
 
-	logExitWithInteger(nByteSent)
+    logExitWithInteger(nByteSent)
 
     return nByteSent;
 }
@@ -339,11 +339,11 @@
 void HTTPChannel::
 setTimeout( long lSeconds)
 {
-	logEntryTransport("HTTPChannel::setTimeout")
+    logEntryTransport("HTTPChannel::setTimeout")
 
     m_lTimeoutSeconds = lSeconds;
-	
-	logExit()
+    
+    logExit()
 }
 
 /**
@@ -426,7 +426,7 @@
 void HTTPChannel::
 setProxy( const char * pcProxyHost, unsigned int uiProxyPort)
 {
-	logEntryTransport("HTTPChannel::setProxy")
+    logEntryTransport("HTTPChannel::setProxy")
 
     m_strProxyHost = pcProxyHost;
     m_uiProxyPort = uiProxyPort;
@@ -452,7 +452,7 @@
 bool HTTPChannel::
 OpenChannel()
 {
-	logEntryTransport("HTTPChannel::OpenChannel")
+    logEntryTransport("HTTPChannel::OpenChannel")
 
     // This method is common to all channel implementations
     bool    bSuccess = (bool) AXIS_FAIL;
@@ -544,7 +544,7 @@
     {
         ReportError();
         
-    	logExitWithBoolean(bSuccess)
+        logExitWithBoolean(bSuccess)
 
         return bSuccess;
     }
@@ -563,7 +563,7 @@
         ReportError();        
         CloseChannel();
         
-    	logExitWithBoolean(bSuccess)
+        logExitWithBoolean(bSuccess)
 
         return bSuccess;
     }
@@ -626,7 +626,7 @@
 
         m_LastError = fullMessage;
 
-    	logExitWithBoolean(bSuccess)
+        logExitWithBoolean(bSuccess)
 
         return bSuccess;
     }
@@ -648,7 +648,7 @@
     int one = 1;
     setsockopt( m_Sock, IPPROTO_TCP, TCP_NODELAY, (char *) &one, sizeof( int));
 
-	logExitWithBoolean(bSuccess)
+    logExitWithBoolean(bSuccess)
 
     return bSuccess;
 }
@@ -665,7 +665,7 @@
 void HTTPChannel::
 CloseChannel()
 {
-	logEntryTransport("HTTPChannel::CloseChannel")
+    logEntryTransport("HTTPChannel::CloseChannel")
 
     if( INVALID_SOCKET != m_Sock)
     {
@@ -676,8 +676,8 @@
 #endif
         m_Sock = INVALID_SOCKET;
     }
-	
-	logExit()
+    
+    logExit()
 }
 
 /**
@@ -766,7 +766,7 @@
 int HTTPChannel::
 applyTimeout()
 {
-	logEntryTransport("HTTPChannel::applyTimeout")
+    logEntryTransport("HTTPChannel::applyTimeout")
 
     fd_set          set;
     struct timeval  timeout;
@@ -785,7 +785,7 @@
     if (rc < 0)
         ReportError();
         
-	logExitWithInteger(rc)
+    logExitWithInteger(rc)
 
     return rc;
 }
@@ -808,6 +808,6 @@
 void HTTPChannel::
 enableTrace(const char* logFilePath, const char *filters)
 {
-	AxisTrace::setLogFilter(filters);
-	AxisTrace::startTrace(logFilePath, false);
+    AxisTrace::setLogFilter(filters);
+    AxisTrace::startTrace(logFilePath, false);
 }
\ No newline at end of file

Modified: webservices/axis/trunk/c/src/transport/axis3/HTTPChannel/HTTPChannel.hpp
URL: http://svn.apache.org/viewvc/webservices/axis/trunk/c/src/transport/axis3/HTTPChannel/HTTPChannel.hpp?rev=722784&r1=722783&r2=722784&view=diff
==============================================================================
--- webservices/axis/trunk/c/src/transport/axis3/HTTPChannel/HTTPChannel.hpp (original)
+++ webservices/axis/trunk/c/src/transport/axis3/HTTPChannel/HTTPChannel.hpp Tue Dec  2 21:31:11 2008
@@ -43,14 +43,14 @@
 #include "../HTTPTransportException.hpp"
 
 #include <unistd.h>
-#include <sys/types.h>		// basic system data types
-#include <sys/socket.h>		// basic socket definitions
+#include <sys/types.h>        // basic system data types
+#include <sys/socket.h>        // basic socket definitions
 #include <netinet/tcp.h>
-#include <fcntl.h>			// for nonblocking if need
+#include <fcntl.h>            // for nonblocking if need
 #include <sys/time.h>
 #include <netdb.h>
 #include <netinet/in.h>
-#include <arpa/inet.h>		// inet(3) functions
+#include <arpa/inet.h>        // inet(3) functions
 
 const int          INVALID_SOCKET = -1;
 const int          SOCKET_ERROR   = -1;
@@ -63,50 +63,50 @@
 class HTTPChannel:public IChannel
 {
 public:
-	HTTPChannel();
-	virtual ~HTTPChannel();
+    HTTPChannel();
+    virtual ~HTTPChannel();
 
-	const char *		getURL();
-	virtual void		setURL( const char * cpURL);
-    virtual URL &		getURLObject();
-    bool				open() throw (HTTPTransportException&);
-    bool				close();
-    const std::string &	GetLastErrorMsg();
+    const char *        getURL();
+    virtual void        setURL( const char * cpURL);
+    virtual URL &        getURLObject();
+    bool                open() throw (HTTPTransportException&);
+    bool                close();
+    const std::string &    GetLastErrorMsg();
     int                 readBytes(char *buf, int bufLen);
     int                 writeBytes(const char *buf, int numBytes);
-    void				setTimeout( long lSeconds);
-    void				setSocket( unsigned int uiNewSocket);
-	int					getSocket() {return m_Sock;}
-	bool				setTransportProperty( AXIS_TRANSPORT_INFORMATION_TYPE type, const char * value);
-	const char *		getTransportProperty( AXIS_TRANSPORT_INFORMATION_TYPE type);
-    void				setProxy( const char * pcProxyHost, unsigned int uiProxyPort);
-	bool		        reopenRequired() { return (INVALID_SOCKET == m_Sock); }
-	void				closeQuietly( bool bNoExceptionOnForceClose);
+    void                setTimeout( long lSeconds);
+    void                setSocket( unsigned int uiNewSocket);
+    int                    getSocket() {return m_Sock;}
+    bool                setTransportProperty( AXIS_TRANSPORT_INFORMATION_TYPE type, const char * value);
+    const char *        getTransportProperty( AXIS_TRANSPORT_INFORMATION_TYPE type);
+    void                setProxy( const char * pcProxyHost, unsigned int uiProxyPort);
+    bool                reopenRequired() { return (INVALID_SOCKET == m_Sock); }
+    void                closeQuietly( bool bNoExceptionOnForceClose);
     void                enableTrace(const char* logFilePath, const char *filters);
 
 
 protected:
-	bool				OpenChannel();
-	void				CloseChannel();
-	bool				StartSockets();
-	void				StopSockets();
-	int					applyTimeout();
-	void				ReportError();
+    bool                OpenChannel();
+    void                CloseChannel();
+    bool                StartSockets();
+    void                StopSockets();
+    int                    applyTimeout();
+    void                ReportError();
 
 private:
-    URL				m_URL;				// URL
-	string			m_LastError;		// Last error
+    URL                m_URL;                // URL
+    string            m_LastError;        // Last error
 #ifdef WIN32
     unsigned 
 #endif
-    int				m_Sock;						// Socket descriptor
-    bool			m_bUseProxy;				// Use a Proxy?
-    std::string		m_strProxyHost;				// Proxy server name.
-    unsigned int	m_uiProxyPort;				// Proxy server port.
-    long			m_lTimeoutSeconds;			// Timeout in seconds
-	bool			bNoExceptionOnForceClose;	// If the socket is forcably closed, usually an
-												// exception is thrown.  When this flag is set,
-												// nothing happens (but the m_Sock is set to 0).
+    int                m_Sock;                        // Socket descriptor
+    bool            m_bUseProxy;                // Use a Proxy?
+    std::string        m_strProxyHost;                // Proxy server name.
+    unsigned int    m_uiProxyPort;                // Proxy server port.
+    long            m_lTimeoutSeconds;            // Timeout in seconds
+    bool            bNoExceptionOnForceClose;    // If the socket is forcably closed, usually an
+                                                // exception is thrown.  When this flag is set,
+                                                // nothing happens (but the m_Sock is set to 0).
 };
 
 #endif

Modified: webservices/axis/trunk/c/src/transport/axis3/HTTPChannel/HTTPChannelInstantiator.cpp
URL: http://svn.apache.org/viewvc/webservices/axis/trunk/c/src/transport/axis3/HTTPChannel/HTTPChannelInstantiator.cpp?rev=722784&r1=722783&r2=722784&view=diff
==============================================================================
--- webservices/axis/trunk/c/src/transport/axis3/HTTPChannel/HTTPChannelInstantiator.cpp (original)
+++ webservices/axis/trunk/c/src/transport/axis3/HTTPChannel/HTTPChannelInstantiator.cpp Tue Dec  2 21:31:11 2008
@@ -30,7 +30,7 @@
     // CreateInstance() Is a C interface.
     STORAGE_CLASS_INFO int CreateInstance( HTTPChannel ** inst)
     {
-		int iSuccess = AXIS_FAIL;
+        int iSuccess = AXIS_FAIL;
 
         *inst = new HTTPChannel();
 
@@ -45,7 +45,7 @@
     // DestroyInstance() Is a C interface.
     STORAGE_CLASS_INFO int DestroyInstance( HTTPChannel * inst)
     {
-		int iSuccess = AXIS_FAIL;
+        int iSuccess = AXIS_FAIL;
 
         if (inst)
         {
@@ -61,7 +61,7 @@
      */
     STORAGE_CLASS_INFO void initializeLibrary (void)
     {
-    	// Do init actions
+        // Do init actions
     }
 
     /*  uninitializeLibrary() Is a C interface.

Modified: webservices/axis/trunk/c/src/transport/axis3/HTTPTransport.cpp
URL: http://svn.apache.org/viewvc/webservices/axis/trunk/c/src/transport/axis3/HTTPTransport.cpp?rev=722784&r1=722783&r2=722784&view=diff
==============================================================================
--- webservices/axis/trunk/c/src/transport/axis3/HTTPTransport.cpp (original)
+++ webservices/axis/trunk/c/src/transport/axis3/HTTPTransport.cpp Tue Dec  2 21:31:11 2008
@@ -81,7 +81,7 @@
 m_bUseProxy (false),
 m_bMaintainSession (false)
 {
-	logEntryTransport("HTTPTransport::HTTPTransport")
+    logEntryTransport("HTTPTransport::HTTPTransport")
 
     m_pcEndpointUri = NULL;
     m_pReleaseBufferCallback = 0;
@@ -117,7 +117,7 @@
 HTTPTransport::
 ~HTTPTransport()
 {
-	logEntryTransport("HTTPTransport::~HTTPTransport")
+    logEntryTransport("HTTPTransport::~HTTPTransport")
 
     delete [] m_pcEndpointUri;
     delete m_pChannelFactory; // should also destroy channels
@@ -129,7 +129,7 @@
 void HTTPTransport::
 resetInputStateMachine()
 {
-	logEntryTransport("HTTPTransport::resetInputStateMachine")
+    logEntryTransport("HTTPTransport::resetInputStateMachine")
 
     m_GetBytesState = eWaitingForHTTPHeader;
     
@@ -154,15 +154,15 @@
 void HTTPTransport::
 setEndpointUri( const char * pcEndpointUri) throw (HTTPTransportException)
 {
-	logEntryTransport("HTTPTransport::setEndpointUri")
+    logEntryTransport("HTTPTransport::setEndpointUri")
 
     logDebugArg1("Endpoint is %s", pcEndpointUri ? pcEndpointUri : "NULL")
 
     // if URI not valid, return
     if (!pcEndpointUri || strlen(pcEndpointUri) < strlen("http://") )
     {
-    	logExit()
-    	
+        logExit()
+        
         return;  
     }
 
@@ -231,7 +231,7 @@
 int HTTPTransport::
 openConnection()
 {
-	logEntryTransport("HTTPTransport::openConnection")
+    logEntryTransport("HTTPTransport::openConnection")
 
     // If connection not valid or reopen required, open a connection to server.
     if (m_pActiveChannel->reopenRequired() || m_bReopenConnection)
@@ -240,15 +240,15 @@
         if( m_pActiveChannel->open() != AXIS_SUCCESS)
         {
             logThrowExceptionWithData("HTTPTransportException - CLIENT_TRANSPORT_OPEN_CONNECTION_FAILED", 
-            		                  m_pActiveChannel->GetLastErrorMsg().c_str())
+                                      m_pActiveChannel->GetLastErrorMsg().c_str())
 
             throw HTTPTransportException( CLIENT_TRANSPORT_OPEN_CONNECTION_FAILED,
                                           m_pActiveChannel->GetLastErrorMsg().c_str());
         }
     }
 
-	logExitWithReturnCode(AXIS_SUCCESS)
-	
+    logExitWithReturnCode(AXIS_SUCCESS)
+    
     return AXIS_SUCCESS;
 }
 
@@ -258,7 +258,7 @@
 void HTTPTransport::
 closeConnection(bool forceClose)
 {
-	logEntryTransport("HTTPTransport::closeConnection")
+    logEntryTransport("HTTPTransport::closeConnection")
 
     resetInputStateMachine();
     
@@ -286,7 +286,7 @@
 AXIS_TRANSPORT_STATUS HTTPTransport::
 flushOutput() throw (AxisException, HTTPTransportException)
 {
-	logEntryTransport("HTTPTransport::flushOutput")
+    logEntryTransport("HTTPTransport::flushOutput")
 
     char *utf8Buf = NULL; // buffer for ebcdic/utf8 conversions.
 
@@ -352,7 +352,7 @@
 const char * HTTPTransport::
 generateHTTPHeaders()
 {
-	logEntryTransport("HTTPTransport::generateHTTPHeaders")
+    logEntryTransport("HTTPTransport::generateHTTPHeaders")
 
     URL & url = m_pActiveChannel->getURLObject();
     unsigned short uiPort;
@@ -498,14 +498,14 @@
 void HTTPTransport::
 setHTTPMethod( const char *cpMethod)
 {
-	logEntryTransport("HTTPTransport::setHTTPMethod")
-	
+    logEntryTransport("HTTPTransport::setHTTPMethod")
+    
     logDebugArg1("HTTP method is %s", cpMethod ? cpMethod : "NULL")
 
     if (cpMethod)
         m_strHTTPMethod = std::string( cpMethod);
-	
-	logExit()
+    
+    logExit()
 }
 
 /* HTTPTransport::sendBytes( SendBuffer, BufferId) Is a public method that
@@ -530,7 +530,7 @@
 bool HTTPTransport::
 isThereResponseData()
 {
-	logEntryTransport("HTTPTransport::isThereResponseData")
+    logEntryTransport("HTTPTransport::isThereResponseData")
 
     // We do not want to consume any SOAP data, just find out if there is any data.
     int bufLen = 0;
@@ -556,7 +556,7 @@
 AXIS_TRANSPORT_STATUS HTTPTransport::
 getBytes( char * pcBuffer, int * piSize) throw (AxisException, HTTPTransportException)
 {
-	logEntryTransport("HTTPTransport::getBytes")
+    logEntryTransport("HTTPTransport::getBytes")
 
     // The method getBytes has three distinct states.  These are defined as
     // follows:-
@@ -623,7 +623,7 @@
 int HTTPTransport::
 getBytes_MessageHasContentLength(char * pcBuffer, int * piSize)
 {
-	logEntryTransport("HTTPTransport::getBytes_MessageHasContentLength")
+    logEntryTransport("HTTPTransport::getBytes_MessageHasContentLength")
 
     // If we do not have data to give back, read more.  
     if (m_iContentLength > 0 && m_iBytesLeft == 0)
@@ -663,7 +663,7 @@
 int HTTPTransport::
 getBytes_MessageIsNotChunked(char * pcBuffer, int * piSize)
 {
-	logEntryTransport("HTTPTransport::getBytes_MessageIsNotChunked")
+    logEntryTransport("HTTPTransport::getBytes_MessageIsNotChunked")
 
     // Keep reading until the connection is closed by the server.
     getNextDataPacket( "Expecting server connection to close.");
@@ -714,7 +714,7 @@
 int HTTPTransport::
 getBytes_MessageIsChunked(char * pcBuffer, int * piSize)
 {
-	logEntryTransport("HTTPTransport::getBytes_MessageIsChunked")
+    logEntryTransport("HTTPTransport::getBytes_MessageIsChunked")
 
     // We only read the next chunk if the chunk we have has been consumed. 
     if (m_iChunkedDataLeftToConsume == 0)
@@ -804,7 +804,7 @@
 int HTTPTransport::
 getChunkSize(string::size_type pos)
 {
-	logEntryTransport("HTTPTransport::getChunkSize")
+    logEntryTransport("HTTPTransport::getChunkSize")
 
     string::size_type iEndOfChunkSize;
     string::size_type iEndOfChunkLine;
@@ -843,7 +843,7 @@
         string errorMessage = string("Chunk size (") + chunkSizeLine + string(") not valid.");
         
         logThrowExceptionWithData("HTTPTransportException - SERVER_TRANSPORT_HTTP_EXCEPTION", errorMessage.c_str())
-               		                  
+                                         
         throw HTTPTransportException(SERVER_TRANSPORT_HTTP_EXCEPTION, errorMessage.c_str());        
     }
 
@@ -882,7 +882,7 @@
 int HTTPTransport::
 setTransportProperty( AXIS_TRANSPORT_INFORMATION_TYPE type, const char *value) throw (HTTPTransportException)
 {
-	logEntryTransport("HTTPTransport::setTransportProperty")
+    logEntryTransport("HTTPTransport::setTransportProperty")
 
     const char *key = NULL;
     int   iSuccess = AXIS_SUCCESS;
@@ -971,7 +971,7 @@
 int HTTPTransport::
 setTransportProperty( const char *pcKey, const char *pcValue) throw (HTTPTransportException)
 {
-	logEntryTransport("HTTPTransport::setTransportProperty")
+    logEntryTransport("HTTPTransport::setTransportProperty")
 
     int   iSuccess = AXIS_SUCCESS;
 
@@ -979,32 +979,32 @@
     {
         logDebugArg2("Transport property to set: %s=%s", pcKey, pcValue)
 
-	    bool b_KeyFound = false;
-	
-	    // Check for well known headers that we add on in every iteration
-	    if (strcmp( pcKey, "SOAPAction") == 0 
-	            || strcmp( pcKey, "Content-Length") == 0
-	            || strcmp( pcKey, "Connection") == 0)
-	    {
-	        std::string strKeyToFind = std::string( pcKey);
-	
-	        for (unsigned int i = 0; i < m_vHTTPHeaders.size(); i++)
-	            if (m_vHTTPHeaders[i].first == strKeyToFind)
-	            {
-	                m_vHTTPHeaders[i].second = (string) pcValue;
-	                b_KeyFound = true;
-	
-	                break;
-	            }
-	    }
-	    else if(strcmp(pcKey, "Cookie")==0)
-	    {
-	    	iSuccess = addCookie(pcValue);
-	    	b_KeyFound = true;
-	    }
-	    
-	    if( !b_KeyFound)
-	        m_vHTTPHeaders.push_back( std::make_pair( (string) pcKey, (string) pcValue));
+        bool b_KeyFound = false;
+    
+        // Check for well known headers that we add on in every iteration
+        if (strcmp( pcKey, "SOAPAction") == 0 
+                || strcmp( pcKey, "Content-Length") == 0
+                || strcmp( pcKey, "Connection") == 0)
+        {
+            std::string strKeyToFind = std::string( pcKey);
+    
+            for (unsigned int i = 0; i < m_vHTTPHeaders.size(); i++)
+                if (m_vHTTPHeaders[i].first == strKeyToFind)
+                {
+                    m_vHTTPHeaders[i].second = (string) pcValue;
+                    b_KeyFound = true;
+    
+                    break;
+                }
+        }
+        else if(strcmp(pcKey, "Cookie")==0)
+        {
+            iSuccess = addCookie(pcValue);
+            b_KeyFound = true;
+        }
+        
+        if( !b_KeyFound)
+            m_vHTTPHeaders.push_back( std::make_pair( (string) pcKey, (string) pcValue));
     }
     
     logExitWithReturnCode(iSuccess)
@@ -1025,7 +1025,7 @@
 const char * HTTPTransport::
 getTransportProperty( AXIS_TRANSPORT_INFORMATION_TYPE eType) throw (HTTPTransportException)
 {
-	logEntryTransport("HTTPTransport::getTransportProperty")
+    logEntryTransport("HTTPTransport::getTransportProperty")
 
     const char *pszPropValue = NULL;
 
@@ -1174,7 +1174,7 @@
 void HTTPTransport::
 setProxy( const char *pcProxyHost, unsigned int uiProxyPort)
 {
-	logEntryTransport("HTTPTransport::setProxy")
+    logEntryTransport("HTTPTransport::setProxy")
 
     logDebugArg2("Proxy host is %s, proxy port is %d", pcProxyHost ? pcProxyHost : "NULL", uiProxyPort)
 
@@ -1195,7 +1195,7 @@
 void HTTPTransport::
 setTimeout( long lSeconds)
 {
-	logEntryTransport("HTTPTransport::setTimeout")
+    logEntryTransport("HTTPTransport::setTimeout")
 
     if( m_pActiveChannel != NULL)
         m_pActiveChannel->setTimeout( lSeconds);
@@ -1277,7 +1277,7 @@
 void HTTPTransport::
 processHTTPHeader()
 {
-	logEntryTransport("HTTPTransport::processHTTPHeader")
+    logEntryTransport("HTTPTransport::processHTTPHeader")
 
     // Prior to calling this method, m_strResponseHTTPHeaders should have been 
     // set to the HTTP header in the response, which is in ascii.  For EBCDIC 
@@ -1444,7 +1444,7 @@
 void HTTPTransport::
 processRootMimeBody()
 {
-	logEntryTransport("HTTPTransport::processRootMimeBody")
+    logEntryTransport("HTTPTransport::processRootMimeBody")
 
     int numberOfBytesRead = 0;
     
@@ -1504,7 +1504,7 @@
 void HTTPTransport::
 processMimeHeader()
 {
-	logEntryTransport("HTTPTransport::processMimeHeader")
+    logEntryTransport("HTTPTransport::processMimeHeader")
 
     string::size_type pos = 0;
     string::size_type temppos = 0;
@@ -1561,7 +1561,7 @@
 void HTTPTransport::
 getAttachment( char * pStrAttachment, int * pIntSize, int intAttachmentId)
 {
-	logEntryTransport("HTTPTransport::getAttachment")
+    logEntryTransport("HTTPTransport::getAttachment")
 
     int numberOfBytesRead = 0;
     
@@ -1591,9 +1591,9 @@
 const char * HTTPTransport::
 getTransportProperty( const char * pcKey, bool response) throw (HTTPTransportException)
 {
-	logEntryTransport("HTTPTransport::getTransportProperty")
-	
-	const char *returnValue = NULL;
+    logEntryTransport("HTTPTransport::getTransportProperty")
+    
+    const char *returnValue = NULL;
 
     std::string strKeyToFind = std::string( pcKey);
     std::vector < std::pair < std::string, std::string > > *hdrs=NULL;
@@ -1606,8 +1606,8 @@
     for( unsigned int i = 0; i < hdrs->size(); i++)
         if( (*hdrs)[i].first == strKeyToFind)
         {
-        	returnValue = (*hdrs)[i].second.c_str();
-        	break;
+            returnValue = (*hdrs)[i].second.c_str();
+            break;
         }
 
     logExitWithString(returnValue)
@@ -1780,7 +1780,7 @@
 void HTTPTransport::
 readHTTPHeader()
 {    
-	logEntryTransport("HTTPTransport::readHTTPHeader")
+    logEntryTransport("HTTPTransport::readHTTPHeader")
 
     m_pActiveChannel->closeQuietly( false);
     
@@ -1814,7 +1814,7 @@
                 m_bReopenConnection = true;
                 
                 logThrowExceptionWithData("HTTPTransportException - SERVER_TRANSPORT_INPUT_STREAMING_ERROR", 
-                		                   "Socket connection has been closed.")
+                                           "Socket connection has been closed.")
 
                 throw HTTPTransportException( SERVER_TRANSPORT_INPUT_STREAMING_ERROR,
                                               "Socket connection has been closed.");
@@ -1848,7 +1848,7 @@
         m_GetBytesState = eWaitingForHTTPHeader;
         
         logThrowExceptionWithData("HTTPTransportException - SERVER_TRANSPORT_HTTP_EXCEPTION", 
-        		                  m_strResponseHTTPStatusMessage.c_str())
+                                  m_strResponseHTTPStatusMessage.c_str())
 
         throw HTTPTransportException( SERVER_TRANSPORT_HTTP_EXCEPTION, m_strResponseHTTPStatusMessage.c_str());
     }  
@@ -1859,7 +1859,7 @@
 int HTTPTransport::
 getNextDataPacket( const char * pcszExceptionMessage, char *bufferToUse, int *bufferLen)
 {
-	logEntryTransport("HTTPTransport::getNextDataPacket")
+    logEntryTransport("HTTPTransport::getNextDataPacket")
 
     int numberOfBytesRead;
 
@@ -1891,7 +1891,7 @@
         if( pcszExceptionMessage != NULL && strlen( pcszExceptionMessage) > 0)
         {
             logThrowExceptionWithData("HTTPTransportException - SERVER_TRANSPORT_HTTP_EXCEPTION", 
-            		                  pcszExceptionMessage)
+                                      pcszExceptionMessage)
 
             throw HTTPTransportException( SERVER_TRANSPORT_HTTP_EXCEPTION, pcszExceptionMessage);
         }
@@ -1905,7 +1905,7 @@
 int HTTPTransport::
 addCookie(const string name, const string value)
 {
-	logEntryTransport("HTTPTransport::addCookie")
+    logEntryTransport("HTTPTransport::addCookie")
 
     // trim the name
     string theName(name);
@@ -1935,7 +1935,7 @@
 int HTTPTransport::
 addCookie(const string nameValuePair)
 {
-	logEntryTransport("HTTPTransport::addCookie")
+    logEntryTransport("HTTPTransport::addCookie")
 
     // Spec syntax : Set-Cookie: NAME=VALUE; expires=DATE; path=PATH; domain=DOMAIN_NAME; secure
     // This code assumes it to be : Set-Cookie: NAME=VALUE; Anything_else
@@ -2002,12 +2002,12 @@
 void HTTPTransport::
 enableTrace(const char* logFilePath, const char *filters)
 {
-	AxisTrace::setLogFilter(filters);
-	AxisTrace::startTrace(logFilePath, false);
-	
-	if (m_pNormalChannel)
-		m_pNormalChannel->enableTrace(logFilePath, filters);
-	
-	if (m_pSecureChannel)
-		m_pSecureChannel->enableTrace(logFilePath, filters);
+    AxisTrace::setLogFilter(filters);
+    AxisTrace::startTrace(logFilePath, false);
+    
+    if (m_pNormalChannel)
+        m_pNormalChannel->enableTrace(logFilePath, filters);
+    
+    if (m_pSecureChannel)
+        m_pSecureChannel->enableTrace(logFilePath, filters);
 }
\ No newline at end of file

Modified: webservices/axis/trunk/c/src/transport/axis3/HTTPTransport.hpp
URL: http://svn.apache.org/viewvc/webservices/axis/trunk/c/src/transport/axis3/HTTPTransport.hpp?rev=722784&r1=722783&r2=722784&view=diff
==============================================================================
--- webservices/axis/trunk/c/src/transport/axis3/HTTPTransport.hpp (original)
+++ webservices/axis/trunk/c/src/transport/axis3/HTTPTransport.hpp Tue Dec  2 21:31:11 2008
@@ -40,9 +40,9 @@
 
 typedef enum
 {
-	eWaitingForHTTPHeader,
-	eSOAPMessageIsChunked,
-	eSOAPMessageIsNotChunked,
+    eWaitingForHTTPHeader,
+    eSOAPMessageIsChunked,
+    eSOAPMessageIsNotChunked,
     eSOAPMessageHasContentLength
 } EGETBYTESSTATE;
 
@@ -59,66 +59,66 @@
     * @param pcEndPointURI End point URI of the service to connect to.
     *                       e.g. http://localhost:8080/axis/services/echo
     */
-    void					setEndpointUri( const char * pszEndpointURI) throw (HTTPTransportException);
-    int						openConnection();
-    void					closeConnection(bool forceClose=true);
-    AXIS_TRANSPORT_STATUS	sendBytes( const char *, const void *);
-    AXIS_TRANSPORT_STATUS	getBytes( char *, int *) throw (AxisException, HTTPTransportException);
-    int						setTransportProperty( AXIS_TRANSPORT_INFORMATION_TYPE, const char *) throw (HTTPTransportException);
-    const char *			getTransportProperty( AXIS_TRANSPORT_INFORMATION_TYPE) throw (HTTPTransportException);
-    int						setTransportProperty( const char *, const char *) throw (HTTPTransportException);
-    const char *			getTransportProperty( const char * pcKey, bool response=true) throw (HTTPTransportException);
-    void					setSessionId( const char * pcSessionId);
-    const char *			getSessionId();
-    const char *			getServiceName ();
+    void                    setEndpointUri( const char * pszEndpointURI) throw (HTTPTransportException);
+    int                        openConnection();
+    void                    closeConnection(bool forceClose=true);
+    AXIS_TRANSPORT_STATUS    sendBytes( const char *, const void *);
+    AXIS_TRANSPORT_STATUS    getBytes( char *, int *) throw (AxisException, HTTPTransportException);
+    int                        setTransportProperty( AXIS_TRANSPORT_INFORMATION_TYPE, const char *) throw (HTTPTransportException);
+    const char *            getTransportProperty( AXIS_TRANSPORT_INFORMATION_TYPE) throw (HTTPTransportException);
+    int                        setTransportProperty( const char *, const char *) throw (HTTPTransportException);
+    const char *            getTransportProperty( const char * pcKey, bool response=true) throw (HTTPTransportException);
+    void                    setSessionId( const char * pcSessionId);
+    const char *            getSessionId();
+    const char *            getServiceName ();
     bool                    isThereResponseData();
     /* HTTPTransport::getProtocol() Is a public method to return the HTTP protocol
-	 * type.
-	 *
-	 * @return AXIS_PROTOCOL_TYPE Type is an enumerated type for valid HTTP
-	 * protocols
-	 */
-    AXIS_PROTOCOL_TYPE		getProtocol();
+     * type.
+     *
+     * @return AXIS_PROTOCOL_TYPE Type is an enumerated type for valid HTTP
+     * protocols
+     */
+    AXIS_PROTOCOL_TYPE        getProtocol();
     /* HTTPTransport::setProtocol() Is a public method to set the HTTP protocol
-	 * type.
-	 *
-	 * @return AXIS_SUCCESS if the set worked and the protocol is supported AXIS_FAIL otherwise
-	 */
-    int						setProtocol( AXIS_PROTOCOL_TYPE eProtocol);
-    int						getSubProtocol();
-    AXIS_TRANSPORT_STATUS	flushOutput() throw (AxisException, HTTPTransportException);
-    void					setProxy( const char *pcProxyHost, unsigned int uiProxyPort);
-    void					setTimeout( long lSeconds);
-    const char *			getHTTPProtocol();
-    const char *			getHTTPMethod();
-    void					setHTTPMethod( const char *);
-    const char *			generateHTTPHeaders();
-    void					setSocket( unsigned int);
-    const char *			getFirstTransportPropertyKey(bool response);
-    const char *			getNextTransportPropertyKey(bool response);
-    const char *			getCurrentTransportPropertyKey(bool response);
-    const char *			getCurrentTransportPropertyValue(bool response);
-    void					deleteCurrentTransportProperty(bool response=true);
-    void					deleteTransportProperty( char* pcKey, unsigned int uiOccurance = 1);
-    virtual void			setMaintainSession( bool bSession);
+     * type.
+     *
+     * @return AXIS_SUCCESS if the set worked and the protocol is supported AXIS_FAIL otherwise
+     */
+    int                        setProtocol( AXIS_PROTOCOL_TYPE eProtocol);
+    int                        getSubProtocol();
+    AXIS_TRANSPORT_STATUS    flushOutput() throw (AxisException, HTTPTransportException);
+    void                    setProxy( const char *pcProxyHost, unsigned int uiProxyPort);
+    void                    setTimeout( long lSeconds);
+    const char *            getHTTPProtocol();
+    const char *            getHTTPMethod();
+    void                    setHTTPMethod( const char *);
+    const char *            generateHTTPHeaders();
+    void                    setSocket( unsigned int);
+    const char *            getFirstTransportPropertyKey(bool response);
+    const char *            getNextTransportPropertyKey(bool response);
+    const char *            getCurrentTransportPropertyKey(bool response);
+    const char *            getCurrentTransportPropertyValue(bool response);
+    void                    deleteCurrentTransportProperty(bool response=true);
+    void                    deleteTransportProperty( char* pcKey, unsigned int uiOccurance = 1);
+    virtual void            setMaintainSession( bool bSession);
 
-    void					setAttachment( const char * pcAttachmentId, const char * pcAttachment) {};
-	ISoapAttachment *		getAttachment( const char * pcAttachmentId) { return NULL;};
+    void                    setAttachment( const char * pcAttachmentId, const char * pcAttachment) {};
+    ISoapAttachment *        getAttachment( const char * pcAttachmentId) { return NULL;};
     ISoapAttachment**       getAllAttachments(int *pAttchArraySize) { return NULL;}; 
-    char *					getIncomingSOAPMimeHeaders() {return NULL;}
-	const char *			getLastChannelError();
-	
+    char *                    getIncomingSOAPMimeHeaders() {return NULL;}
+    const char *            getLastChannelError();
+    
     void enableTrace(const char* logFilePath, const char *filters);
 
   protected:
-    void					processRootMimeBody();
-    void					processMimeHeader();
-    void					processMimeBody();
-    void					getAttachment( char* pStrAttachment, int* pIntSize, int intAttachmentId);
-    int						FindTransportPropertyIndex( std::string);
-	void					readHTTPHeader();
-	void					processHTTPHeader();
-	int 					getNextDataPacket( const char * pcszExceptionMessage, char *bufferToUse=NULL, int *bufferLen=NULL);
+    void                    processRootMimeBody();
+    void                    processMimeHeader();
+    void                    processMimeBody();
+    void                    getAttachment( char* pStrAttachment, int* pIntSize, int intAttachmentId);
+    int                        FindTransportPropertyIndex( std::string);
+    void                    readHTTPHeader();
+    void                    processHTTPHeader();
+    int                     getNextDataPacket( const char * pcszExceptionMessage, char *bufferToUse=NULL, int *bufferLen=NULL);
     int                     getBytes_MessageIsChunked(char * pcBuffer, int * piSize);
     int                     getBytes_MessageIsNotChunked(char * pcBuffer, int * piSize);
     int                     getBytes_MessageHasContentLength(char * pcBuffer, int * piSize);
@@ -258,15 +258,15 @@
   /**
     * Channel used for communication
     */
-    IChannel *	m_pNormalChannel;
-    IChannel *	m_pSecureChannel;
-    IChannel *	m_pActiveChannel;
-    bool		m_bChannelSecure;
+    IChannel *    m_pNormalChannel;
+    IChannel *    m_pSecureChannel;
+    IChannel *    m_pActiveChannel;
+    bool        m_bChannelSecure;
 
   /**
     * Message header string to be sent.
     */
-    std::string m_strHeaderBytesToSend;	
+    std::string m_strHeaderBytesToSend;    
     
   /**
     * Should the Stub maintain session with service?
@@ -316,16 +316,16 @@
     std::string m_strMimeReceived;
     ChannelFactory* m_pChannelFactory;
 
-	char *	m_pszRxBuffer;
+    char *    m_pszRxBuffer;
 
-	long	m_lChannelTimeout;
+    long    m_lChannelTimeout;
 
-	std::string	m_strBuffered;
+    std::string    m_strBuffered;
 
   /**
     * New getBytes variables
-	*/
-	EGETBYTESSTATE	m_GetBytesState;
+    */
+    EGETBYTESSTATE    m_GetBytesState;
 };
 
 #endif

Modified: webservices/axis/trunk/c/src/xml/AnyElement.h
URL: http://svn.apache.org/viewvc/webservices/axis/trunk/c/src/xml/AnyElement.h?rev=722784&r1=722783&r2=722784&view=diff
==============================================================================
--- webservices/axis/trunk/c/src/xml/AnyElement.h (original)
+++ webservices/axis/trunk/c/src/xml/AnyElement.h Tue Dec  2 21:31:11 2008
@@ -78,12 +78,12 @@
     /**
      * Local name in case of StartElement or EndElement event. Character data
      * in case of character data event. Namespace prefix in case of prefix 
-	 * prefix mapping event.
+     * prefix mapping event.
      */
     const char* m_pchNameOrValue;
     /**
      * Namespace of StartElemnt or EndElement tag. In case there is no 
-	 * namespace this should be NULL (not pointing to empty string "" even)
+     * namespace this should be NULL (not pointing to empty string "" even)
      */
     const char* m_pchNamespace;
     /**
@@ -107,7 +107,7 @@
     public:
         static string toString(const AnyElement* pNode)
         {
-            string sTmpVal;              			                                                                                                                                                  
+            string sTmpVal;                                                                                                                                                                            
             switch(pNode->m_type)
             {
                 case CHARACTER_ELEMENT:

Modified: webservices/axis/trunk/c/src/xml/Event.h
URL: http://svn.apache.org/viewvc/webservices/axis/trunk/c/src/xml/Event.h?rev=722784&r1=722783&r2=722784&view=diff
==============================================================================
--- webservices/axis/trunk/c/src/xml/Event.h (original)
+++ webservices/axis/trunk/c/src/xml/Event.h Tue Dec  2 21:31:11 2008
@@ -33,7 +33,7 @@
 public:
     Event();
     virtual ~Event();
-	/* character data, element name or prefix(in case of prefix mapping event) */
+    /* character data, element name or prefix(in case of prefix mapping event) */
     string m_NameOrValue; 
 public:
     virtual XML_NODE_TYPE getType(){ return CHARACTER_ELEMENT;};

Modified: webservices/axis/trunk/c/src/xml/XMLParser.h
URL: http://svn.apache.org/viewvc/webservices/axis/trunk/c/src/xml/XMLParser.h?rev=722784&r1=722783&r2=722784&view=diff
==============================================================================
--- webservices/axis/trunk/c/src/xml/XMLParser.h (original)
+++ webservices/axis/trunk/c/src/xml/XMLParser.h Tue Dec  2 21:31:11 2008
@@ -123,7 +123,7 @@
     
     /**
      * Used to get the next XML data event. The valid events are start element, 
-	 * end element and character data. If we think of SAX events the processing 
+     * end element and character data. If we think of SAX events the processing 
      * instruction events, namespace prefix mapping events are not returned by
      * this method. If the implementation of this interface is wrapping up a 
      * SAX parser it should follow the above rules.

Modified: webservices/axis/trunk/c/src/xml/xerces/ParserLoader.cpp
URL: http://svn.apache.org/viewvc/webservices/axis/trunk/c/src/xml/xerces/ParserLoader.cpp?rev=722784&r1=722783&r2=722784&view=diff
==============================================================================
--- webservices/axis/trunk/c/src/xml/xerces/ParserLoader.cpp (original)
+++ webservices/axis/trunk/c/src/xml/xerces/ParserLoader.cpp Tue Dec  2 21:31:11 2008
@@ -36,31 +36,31 @@
 STORAGE_CLASS_INFO
 int CreateInstance(XMLParser **inst)
 {
-	/* TODO : Following initialization should be done within a function
-	          called by the library loader at loading time */
+    /* TODO : Following initialization should be done within a function
+              called by the library loader at loading time */
     XMLPlatformUtils::Initialize();
-	*inst = new XMLParserXerces();
-	if (*inst)
-	{
-		return AXIS_SUCCESS;
-	}
-	return AXIS_FAIL;
+    *inst = new XMLParserXerces();
+    if (*inst)
+    {
+        return AXIS_SUCCESS;
+    }
+    return AXIS_FAIL;
 }
 STORAGE_CLASS_INFO 
 int DestroyInstance(XMLParser *inst)
 {
-	if (inst)
-	{
-		delete inst;
-	/* TODO : Following uninitialization should be done within a function
-	          called by the library loader at unloading time */
-		XMLPlatformUtils::Terminate ();
+    if (inst)
+    {
+        delete inst;
+    /* TODO : Following uninitialization should be done within a function
+              called by the library loader at unloading time */
+        XMLPlatformUtils::Terminate ();
 #ifdef AXIS_XML4C
-		u_cleanup();
+        u_cleanup();
 #endif
-		return AXIS_SUCCESS;
-	}
-	return AXIS_FAIL;
+        return AXIS_SUCCESS;
+    }
+    return AXIS_FAIL;
 }
 
 STORAGE_CLASS_INFO void initializeLibrary (void)

Modified: webservices/axis/trunk/c/src/xml/xerces/SoapBinInputStream.cpp
URL: http://svn.apache.org/viewvc/webservices/axis/trunk/c/src/xml/xerces/SoapBinInputStream.cpp?rev=722784&r1=722783&r2=722784&view=diff
==============================================================================
--- webservices/axis/trunk/c/src/xml/xerces/SoapBinInputStream.cpp (original)
+++ webservices/axis/trunk/c/src/xml/xerces/SoapBinInputStream.cpp Tue Dec  2 21:31:11 2008
@@ -45,7 +45,7 @@
                                            const unsigned int iMaxToRead)
 {
     int iRead = iMaxToRead;
-	m_pInputStream->getBytes((char*)pcToFill, &iRead);
-	m_nByteCount += iRead;
+    m_pInputStream->getBytes((char*)pcToFill, &iRead);
+    m_nByteCount += iRead;
     return iRead;
 }

Modified: webservices/axis/trunk/c/src/xml/xerces/SoapInputSource.cpp
URL: http://svn.apache.org/viewvc/webservices/axis/trunk/c/src/xml/xerces/SoapInputSource.cpp?rev=722784&r1=722783&r2=722784&view=diff
==============================================================================
--- webservices/axis/trunk/c/src/xml/xerces/SoapInputSource.cpp (original)
+++ webservices/axis/trunk/c/src/xml/xerces/SoapInputSource.cpp Tue Dec  2 21:31:11 2008
@@ -28,7 +28,7 @@
 
 SoapInputSource::~SoapInputSource()
 {
-	/* do not delete the m_pInputStream. See Xerces documentation */
+    /* do not delete the m_pInputStream. See Xerces documentation */
 }
 
 BinInputStream* SoapInputSource::makeStream() const

Modified: webservices/axis/trunk/c/src/xml/xerces/XMLParserXerces.cpp
URL: http://svn.apache.org/viewvc/webservices/axis/trunk/c/src/xml/xerces/XMLParserXerces.cpp?rev=722784&r1=722783&r2=722784&view=diff
==============================================================================
--- webservices/axis/trunk/c/src/xml/xerces/XMLParserXerces.cpp (original)
+++ webservices/axis/trunk/c/src/xml/xerces/XMLParserXerces.cpp Tue Dec  2 21:31:11 2008
@@ -32,7 +32,7 @@
 XMLParserXerces::
 XMLParserXerces() : XMLParser()
 {
-	logEntryParser("XMLParserXerces::XMLParserXerces")
+    logEntryParser("XMLParserXerces::XMLParserXerces")
 
     m_pInputSource = NULL;
     m_bFirstParsed = false;
@@ -47,7 +47,7 @@
 XMLParserXerces::
 ~XMLParserXerces()
 {
-	logEntryParser("XMLParserXerces::~XMLParserXerces")
+    logEntryParser("XMLParserXerces::~XMLParserXerces")
 
     // Parser has memory allocated with the last AnyElement parsed; clean that
     m_Xhandler.freeElement();
@@ -61,7 +61,7 @@
 int XMLParserXerces::
 setInputStream(AxisIOStream* pInputStream)
 {
-	logEntryParser("XMLParserXerces::setInputStream")
+    logEntryParser("XMLParserXerces::setInputStream")
 
     m_pInputStream = pInputStream;
     
@@ -92,7 +92,7 @@
 const AnyElement* XMLParserXerces::
 parse(bool ignoreWhitespace, bool peekIt)
 {
-	logEntryParser("XMLParserXerces::parse")
+    logEntryParser("XMLParserXerces::parse")
 
     try 
     {
@@ -231,13 +231,13 @@
 const AnyElement* XMLParserXerces::
 next(bool isCharData)
 {    
-	logEntryParser("XMLParserXerces::next")
+    logEntryParser("XMLParserXerces::next")
 
     const AnyElement* returnValue = parse(isCharData ? false : true);
-	
+    
     logExitWithPointer(returnValue)
 
-	return returnValue;
+    return returnValue;
 }
 
 // New method which peek a head next element 
@@ -245,7 +245,7 @@
 const char* XMLParserXerces::
 peek()
 {   
-	logEntryParser("XMLParserXerces::peek")
+    logEntryParser("XMLParserXerces::peek")
 
     const char* returnValue = "";
 
@@ -254,15 +254,15 @@
     // the last node processed was a start/end element
     if (!m_bStartEndElement)
     {
-	    // get element, ignoring whitespace and indicating this is a peek operation   
-	    const AnyElement* elem = parse(true, true);
-	    if (elem)
-	    {
-		    // We return null string if end-element or unknown type is encountered
-		    const XML_NODE_TYPE type = m_Xhandler.peekNextElementType();
-		    if(type != END_ELEMENT && type != END_PREFIX && type != UNKNOWN)
-		    	returnValue = m_Xhandler.peekNextElementName();
-	    }
+        // get element, ignoring whitespace and indicating this is a peek operation   
+        const AnyElement* elem = parse(true, true);
+        if (elem)
+        {
+            // We return null string if end-element or unknown type is encountered
+            const XML_NODE_TYPE type = m_Xhandler.peekNextElementType();
+            if(type != END_ELEMENT && type != END_PREFIX && type != UNKNOWN)
+                returnValue = m_Xhandler.peekNextElementName();
+        }
     }
     
     logExitWithString(returnValue)
@@ -273,7 +273,7 @@
 const AnyElement* XMLParserXerces::
 anyNext()
 {
-	logEntryParser("XMLParserXerces::anyNext")
+    logEntryParser("XMLParserXerces::anyNext")
 
     // Say the SAX event handler to record prefix mappings too 
     // By default the event handler do not record them.
@@ -299,6 +299,6 @@
 void XMLParserXerces::
 enableTrace(const char* logFilePath, const char *filters)
 {
-	AxisTrace::setLogFilter(filters);
-	AxisTrace::startTrace(logFilePath, false);
+    AxisTrace::setLogFilter(filters);
+    AxisTrace::startTrace(logFilePath, false);
 }
\ No newline at end of file

Modified: webservices/axis/trunk/c/src/xml/xerces/XercesHandler.h
URL: http://svn.apache.org/viewvc/webservices/axis/trunk/c/src/xml/xerces/XercesHandler.h?rev=722784&r1=722783&r2=722784&view=diff
==============================================================================
--- webservices/axis/trunk/c/src/xml/xerces/XercesHandler.h (original)
+++ webservices/axis/trunk/c/src/xml/xerces/XercesHandler.h Tue Dec  2 21:31:11 2008
@@ -38,11 +38,11 @@
     ~XercesHandler();
     const XML_Ch* ns4Prefix(const XML_Ch* prefix);
     const XML_Ch* prefix4NS(const XML_Ch* pcNS);
-	AnyElement* getAnyElement();
-	const char* peekNextElementName();
-	const XML_NODE_TYPE peekNextElementType();
-	void setGetPrefixMappings(bool bValue);
-	void reset();
+    AnyElement* getAnyElement();
+    const char* peekNextElementName();
+    const XML_NODE_TYPE peekNextElementType();
+    void setGetPrefixMappings(bool bValue);
+    void reset();
 
 private:
     /* -----------------------------------------------------------------------
@@ -78,14 +78,14 @@
     // Report a fatal XML parsing error.
     void fatalError(const SAXParseException& exception);
 
-	bool m_bEndElementFollows;
+    bool m_bEndElementFollows;
     AnyElement* m_pNextElement;
     AnyElement* m_pPrefixMappingElement;
     AnyElement* m_pCurrElement;
     map<AxisXMLString, AxisXMLString> m_NsStack;
-	map<const AxisChar*, const AxisChar*> m_CurrPrefixMappings;
-	bool m_bGetPrefixMappings;
-	bool m_bStartElementWaiting;
-	void freeAttributes();
+    map<const AxisChar*, const AxisChar*> m_CurrPrefixMappings;
+    bool m_bGetPrefixMappings;
+    bool m_bStartElementWaiting;
+    void freeAttributes();
 };