You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@logging.apache.org by ts...@apache.org on 2018/08/19 11:48:11 UTC

[2/3] logging-log4cxx git commit: LOGCXX-500: Remove unnecessary whitespace for easier applying of patches.

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/filter/propertyfilter.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/filter/propertyfilter.h b/src/main/include/log4cxx/filter/propertyfilter.h
index 4d830e1..d38d02b 100644
--- a/src/main/include/log4cxx/filter/propertyfilter.h
+++ b/src/main/include/log4cxx/filter/propertyfilter.h
@@ -48,7 +48,7 @@ namespace log4cxx
  * Example properties param:
  * somename=somevalue,anothername=anothervalue,thirdname=third value
  *
- * 
+ *
  */
         class LOG4CXX_EXPORT PropertyFilter : public log4cxx::spi::Filter
         {

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/appenderattachableimpl.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/appenderattachableimpl.h b/src/main/include/log4cxx/helpers/appenderattachableimpl.h
index d254e34..62e1dcf 100644
--- a/src/main/include/log4cxx/helpers/appenderattachableimpl.h
+++ b/src/main/include/log4cxx/helpers/appenderattachableimpl.h
@@ -48,10 +48,10 @@ namespace log4cxx
             /** Array of appenders. */
             AppenderList  appenderList;
 
-        public:            
+        public:
             /**
              *   Create new instance.
-             *   @param pool pool, must be longer-lived than instance. 
+             *   @param pool pool, must be longer-lived than instance.
              */
             AppenderAttachableImpl(Pool& pool);
 

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/aprinitializer.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/aprinitializer.h b/src/main/include/log4cxx/helpers/aprinitializer.h
index 2d64e99..1a91a7a 100644
--- a/src/main/include/log4cxx/helpers/aprinitializer.h
+++ b/src/main/include/log4cxx/helpers/aprinitializer.h
@@ -36,7 +36,7 @@ namespace log4cxx
   namespace helpers
   {
     class FileWatchdog;
-    
+
     class APRInitializer
     {
     public:
@@ -44,10 +44,10 @@ namespace log4cxx
     static apr_pool_t* getRootPool();
     static apr_threadkey_t* getTlsKey();
     static bool isDestructed;
-    
+
     /**
      *  Register a FileWatchdog for deletion prior to
-     *    APR termination.  FileWatchdog must be 
+     *    APR termination.  FileWatchdog must be
      *    allocated on heap and not deleted elsewhere.
      */
     static void registerCleanup(FileWatchdog* watchdog);
@@ -59,7 +59,7 @@ namespace log4cxx
       APRInitializer& operator=(const APRInitializer&);
       apr_pool_t* p;
       apr_thread_mutex_t* mutex;
-      std::list<FileWatchdog*> watchdogs; 
+      std::list<FileWatchdog*> watchdogs;
       apr_time_t startTime;
       apr_threadkey_t* tlsKey;
       static APRInitializer& getInstance();

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/bytearrayinputstream.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/bytearrayinputstream.h b/src/main/include/log4cxx/helpers/bytearrayinputstream.h
index 11d33de..3596925 100644
--- a/src/main/include/log4cxx/helpers/bytearrayinputstream.h
+++ b/src/main/include/log4cxx/helpers/bytearrayinputstream.h
@@ -60,7 +60,7 @@ namespace log4cxx
                    virtual ~ByteArrayInputStream();
 
                   /**
-                   * Closes this file input stream and releases any system 
+                   * Closes this file input stream and releases any system
                    * resources associated with the stream.
                    */
                   virtual void close();

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/charsetdecoder.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/charsetdecoder.h b/src/main/include/log4cxx/helpers/charsetdecoder.h
index cb8320a..e2b1ea1 100644
--- a/src/main/include/log4cxx/helpers/charsetdecoder.h
+++ b/src/main/include/log4cxx/helpers/charsetdecoder.h
@@ -72,8 +72,8 @@ namespace log4cxx
                *   Get decoder for ISO-8859-1.
                */
                   static CharsetDecoderPtr getISOLatinDecoder();
-                  
-                  
+
+
 
               /**
                *  Decodes as many bytes as possible from the given

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/condition.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/condition.h b/src/main/include/log4cxx/helpers/condition.h
index 7adb3bc..3da4262 100644
--- a/src/main/include/log4cxx/helpers/condition.h
+++ b/src/main/include/log4cxx/helpers/condition.h
@@ -33,7 +33,7 @@ namespace log4cxx
 
                 /**
                  *   This class provides a means for one thread to suspend exception until
-                 *   notified by another thread to resume.  This class should have 
+                 *   notified by another thread to resume.  This class should have
                  *   similar semantics to java.util.concurrent.locks.Condition.
                  */
                 class LOG4CXX_EXPORT Condition

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/cyclicbuffer.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/cyclicbuffer.h b/src/main/include/log4cxx/helpers/cyclicbuffer.h
index 2cd913d..dbf9ce9 100644
--- a/src/main/include/log4cxx/helpers/cyclicbuffer.h
+++ b/src/main/include/log4cxx/helpers/cyclicbuffer.h
@@ -26,7 +26,7 @@ namespace log4cxx
         {
                 /**
                 CyclicBuffer is used by other appenders to hold instances of
-                {@link log4cxx::spi::LoggingEvent LoggingEvent} for immediate 
+                {@link log4cxx::spi::LoggingEvent LoggingEvent} for immediate
                 or deferred display.
                 <p>This buffer gives read access to any element in the buffer not
                 just the first or last element.

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/exception.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/exception.h b/src/main/include/log4cxx/helpers/exception.h
index fb1daf5..0bfcae8 100644
--- a/src/main/include/log4cxx/helpers/exception.h
+++ b/src/main/include/log4cxx/helpers/exception.h
@@ -250,7 +250,7 @@ namespace log4cxx
                       BindException(const BindException&);
                       BindException& operator=(const BindException&);
                 };
-               
+
                 /** Signals that an I/O operation has been interrupted. An
                 InterruptedIOException is thrown to indicate that an input or output
                 transfer has been terminated because the thread performing it was
@@ -265,7 +265,7 @@ namespace log4cxx
                      InterruptedIOException& operator=(const InterruptedIOException&);
                 };
 
-               
+
                 /** Signals that an I/O operation has been interrupted. An
                 InterruptedIOException is thrown to indicate that an input or output
                 transfer has been terminated because the thread performing it was
@@ -279,7 +279,7 @@ namespace log4cxx
                      SocketTimeoutException(const SocketTimeoutException&);
                      SocketTimeoutException& operator=(const SocketTimeoutException&);
                 };
-                 
+
 
         }  // namespace helpers
 } // namespace log4cxx

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/fileinputstream.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/fileinputstream.h b/src/main/include/log4cxx/helpers/fileinputstream.h
index fdf658a..bfd4f92 100644
--- a/src/main/include/log4cxx/helpers/fileinputstream.h
+++ b/src/main/include/log4cxx/helpers/fileinputstream.h
@@ -30,7 +30,7 @@ namespace log4cxx
 
           /**
            * InputStream implemented on top of APR file IO.
-           * 
+           *
            */
           class LOG4CXX_EXPORT FileInputStream : public InputStream
           {
@@ -55,7 +55,7 @@ namespace log4cxx
                   FileInputStream(const logchar* filename);
 
                   /**
-                   * Creates a FileInputStream by opening a connection to an actual 
+                   * Creates a FileInputStream by opening a connection to an actual
                    * file, the file named by the File object file in the file system.
                    *
                    * @param aFile The file to be opened for reading.
@@ -65,7 +65,7 @@ namespace log4cxx
                   virtual ~FileInputStream();
 
                   /**
-                   * Closes this file input stream and releases any system 
+                   * Closes this file input stream and releases any system
                    * resources associated with the stream.
                    */
                   virtual void close();

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/fileoutputstream.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/fileoutputstream.h b/src/main/include/log4cxx/helpers/fileoutputstream.h
index d66e4aa..86ab41e 100644
--- a/src/main/include/log4cxx/helpers/fileoutputstream.h
+++ b/src/main/include/log4cxx/helpers/fileoutputstream.h
@@ -58,7 +58,7 @@ namespace log4cxx
           private:
                   FileOutputStream(const FileOutputStream&);
                   FileOutputStream& operator=(const FileOutputStream&);
-                  static apr_file_t* open(const LogString& fn, bool append, 
+                  static apr_file_t* open(const LogString& fn, bool append,
          log4cxx::helpers::Pool& p);
           };
 

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/inputstream.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/inputstream.h b/src/main/include/log4cxx/helpers/inputstream.h
index 585d4f0..2885212 100644
--- a/src/main/include/log4cxx/helpers/inputstream.h
+++ b/src/main/include/log4cxx/helpers/inputstream.h
@@ -28,7 +28,7 @@ namespace log4cxx
 
           /**
            * Abstract class for reading from character streams.
-           * 
+           *
            */
           class LOG4CXX_EXPORT InputStream : public ObjectImpl
           {
@@ -54,7 +54,7 @@ namespace log4cxx
                   virtual int read(ByteBuffer& dst) = 0;
 
                   /**
-                   * Closes this input stream and releases any system 
+                   * Closes this input stream and releases any system
                    * resources associated with the stream.
                    */
                   virtual void close() = 0;

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/inputstreamreader.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/inputstreamreader.h b/src/main/include/log4cxx/helpers/inputstreamreader.h
index 1f186d9..b2f1057 100644
--- a/src/main/include/log4cxx/helpers/inputstreamreader.h
+++ b/src/main/include/log4cxx/helpers/inputstreamreader.h
@@ -29,7 +29,7 @@ namespace log4cxx
 
           /**
            * Class for reading from character streams.
-           * Decorates a byte based InputStream and provides appropriate 
+           * Decorates a byte based InputStream and provides appropriate
            * conversion to characters.
            */
           class LOG4CXX_EXPORT InputStreamReader : public Reader

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/loglog.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/loglog.h b/src/main/include/log4cxx/helpers/loglog.h
index 3c1f133..913a0ef 100644
--- a/src/main/include/log4cxx/helpers/loglog.h
+++ b/src/main/include/log4cxx/helpers/loglog.h
@@ -53,7 +53,7 @@ namespace log4cxx
                         LogLog(const LogLog&);
                         LogLog& operator=(const LogLog&);
                         static LogLog& getInstance();
- 
+
 
                 public:
                         /**
@@ -84,7 +84,7 @@ namespace log4cxx
 
                         @param quietMode <code>true</code> for no output.
                         */
-                        static void setQuietMode(bool quietMode);     
+                        static void setQuietMode(bool quietMode);
 
                         /**
                         This method is used to output log4cxx internal warning

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/messagebuffer.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/messagebuffer.h b/src/main/include/log4cxx/helpers/messagebuffer.h
index c026dc5..3335caf 100644
--- a/src/main/include/log4cxx/helpers/messagebuffer.h
+++ b/src/main/include/log4cxx/helpers/messagebuffer.h
@@ -26,7 +26,7 @@ namespace log4cxx {
 
 
    namespace helpers {
-   
+
    typedef std::ios_base& (*ios_base_manip)(std::ios_base&);
 
    /**
@@ -45,7 +45,7 @@ namespace log4cxx {
          */
         ~CharMessageBuffer();
 
-        
+
         /**
          *   Appends string to buffer.
          *   @param msg string append.
@@ -171,7 +171,7 @@ namespace log4cxx {
          */
       CharMessageBuffer(const CharMessageBuffer&);
         /**
-         *   Prevent use of default assignment operator.  
+         *   Prevent use of default assignment operator.
          */
       CharMessageBuffer& operator=(const CharMessageBuffer&);
 
@@ -206,10 +206,10 @@ std::basic_ostream<char>& operator<<(CharMessageBuffer& os, const V& val) {
          *  Destructor.
          */
         ~UniCharMessageBuffer();
-        
+
         typedef std::basic_ostream<UniChar> uostream;
 
-        
+
         /**
          *   Appends string to buffer.
          *   @param msg string append.
@@ -235,7 +235,7 @@ std::basic_ostream<char>& operator<<(CharMessageBuffer& os, const V& val) {
          *   @return this buffer.
          */
         UniCharMessageBuffer& operator<<(const UniChar msg);
-        
+
 #if LOG4CXX_CFSTRING_API
       /**
          *   Appends a string into the buffer and
@@ -244,7 +244,7 @@ std::basic_ostream<char>& operator<<(CharMessageBuffer& os, const V& val) {
          *   @return encapsulated CharMessageBuffer.
          */
         UniCharMessageBuffer& operator<<(const CFStringRef& msg);
-#endif        
+#endif
 
         /**
          *   Insertion operator for STL manipulators such as std::fixed.
@@ -346,7 +346,7 @@ std::basic_ostream<char>& operator<<(CharMessageBuffer& os, const V& val) {
          */
       UniCharMessageBuffer(const UniCharMessageBuffer&);
         /**
-         *   Prevent use of default assignment operator.  
+         *   Prevent use of default assignment operator.
          */
       UniCharMessageBuffer& operator=(const UniCharMessageBuffer&);
 
@@ -383,7 +383,7 @@ UniCharMessageBuffer::uostream& operator<<(UniCharMessageBuffer& os, const V& va
          */
         ~WideMessageBuffer();
 
-        
+
         /**
          *   Appends string to buffer.
          *   @param msg string append.
@@ -510,7 +510,7 @@ UniCharMessageBuffer::uostream& operator<<(UniCharMessageBuffer& os, const V& va
          */
       WideMessageBuffer(const WideMessageBuffer&);
         /**
-         *   Prevent use of default assignment operator.  
+         *   Prevent use of default assignment operator.
          */
       WideMessageBuffer& operator=(const WideMessageBuffer&);
 
@@ -590,7 +590,7 @@ std::basic_ostream<wchar_t>& operator<<(WideMessageBuffer& os, const V& val) {
 
       /**
        *   Get content of buffer.
-       *   @param os used only to signal 
+       *   @param os used only to signal
        *       the character type and that
        *       the embedded stream was used.
        */
@@ -744,12 +744,12 @@ std::basic_ostream<wchar_t>& operator<<(WideMessageBuffer& os, const V& val) {
 
       /**
        *   Get content of buffer.
-       *   @param os used only to signal 
+       *   @param os used only to signal
        *       the character type and that
        *       the embedded stream was used.
        */
       const std::wstring& str(std::basic_ostream<wchar_t>& os);
-        
+
 #if LOG4CXX_UNICHAR_API || LOG4CXX_CFSTRING_API
       /**
        *   Get content of buffer.
@@ -761,12 +761,12 @@ std::basic_ostream<wchar_t>& operator<<(WideMessageBuffer& os, const V& val) {
 
       /**
        *   Get content of buffer.
-       *   @param os used only to signal 
+       *   @param os used only to signal
        *       the character type and that
        *       the embedded stream was used.
        */
       const std::basic_string<UniChar>& str(UniCharMessageBuffer::uostream& os);
-#endif        
+#endif
 
         /**
          *  Returns true if buffer has an encapsulated STL stream.
@@ -780,7 +780,7 @@ std::basic_ostream<wchar_t>& operator<<(WideMessageBuffer& os, const V& val) {
          */
         MessageBuffer(const MessageBuffer&);
         /**
-         *   Prevent use of default assignment operator.  
+         *   Prevent use of default assignment operator.
          */
         MessageBuffer& operator=(const MessageBuffer&);
 
@@ -792,13 +792,13 @@ std::basic_ostream<wchar_t>& operator<<(WideMessageBuffer& os, const V& val) {
         /**
          * Encapsulated wide message buffer, created on demand.
          */
-        WideMessageBuffer* wbuf;        
+        WideMessageBuffer* wbuf;
 #if LOG4CXX_UNICHAR_API || LOG4CXX_CFSTRING_API
         /**
          * Encapsulated wide message buffer, created on demand.
          */
-        UniCharMessageBuffer* ubuf;        
-#endif        
+        UniCharMessageBuffer* ubuf;
+#endif
    };
 
 template<class V>

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/optionconverter.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/optionconverter.h b/src/main/include/log4cxx/helpers/optionconverter.h
index 6b4561c..0aa3115 100644
--- a/src/main/include/log4cxx/helpers/optionconverter.h
+++ b/src/main/include/log4cxx/helpers/optionconverter.h
@@ -110,7 +110,7 @@ balanced by a stop delimeter "}". </p>
                         static LogString substVars(const LogString& val, Properties& props);
 
                         /**
-                         *  Gets the specified system property.  
+                         *  Gets the specified system property.
                         @param key The key to search for.
                         @param def The default value to return.
                         @return the string value of the system property, or the default

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/reader.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/reader.h b/src/main/include/log4cxx/helpers/reader.h
index f61ca66..488b5fd 100644
--- a/src/main/include/log4cxx/helpers/reader.h
+++ b/src/main/include/log4cxx/helpers/reader.h
@@ -27,7 +27,7 @@ namespace log4cxx
 
           /**
            * Abstract class for reading from character streams.
-           * 
+           *
            */
           class LOG4CXX_EXPORT Reader : public ObjectImpl
           {

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/serversocket.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/serversocket.h b/src/main/include/log4cxx/helpers/serversocket.h
index 7f0c90b..5eee0ee 100644
--- a/src/main/include/log4cxx/helpers/serversocket.h
+++ b/src/main/include/log4cxx/helpers/serversocket.h
@@ -50,13 +50,13 @@ namespace log4cxx
                         /** Enable/disable SO_TIMEOUT with the specified timeout, in milliseconds.
                         */
                         void setSoTimeout(int timeout);
-                        
+
                 private:
                         Pool pool;
                         Mutex mutex;
                         apr_socket_t* socket;
                         int timeout;
-                        
+
                 };
         }  // namespace helpers
 } // namespace log4cxx

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/simpledateformat.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/simpledateformat.h b/src/main/include/log4cxx/helpers/simpledateformat.h
index dc18fcb..42a930f 100644
--- a/src/main/include/log4cxx/helpers/simpledateformat.h
+++ b/src/main/include/log4cxx/helpers/simpledateformat.h
@@ -81,7 +81,7 @@ namespace log4cxx
                    * List of tokens.
                    */
                   PatternTokenList pattern;
-                  
+
                   static void addToken(const logchar spec, const int repeat, const std::locale* locale, PatternTokenList& pattern);
                   static void parsePattern(const LogString& spec, const std::locale* locale, PatternTokenList& pattern);
           };

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/socket.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/socket.h b/src/main/include/log4cxx/helpers/socket.h
index 2f1636b..6b41a64 100644
--- a/src/main/include/log4cxx/helpers/socket.h
+++ b/src/main/include/log4cxx/helpers/socket.h
@@ -31,7 +31,7 @@ namespace log4cxx
 {
         namespace helpers
         {
-                class ByteBuffer;                
+                class ByteBuffer;
                 /**
                 <p>This class implements client sockets (also called just "sockets"). A socket
                 is an endpoint for communication between two machines.
@@ -59,7 +59,7 @@ namespace log4cxx
 
                         /** Closes this socket. */
                         void close();
-                                
+
                         /** Returns the value of this socket's address field. */
                         InetAddressPtr getInetAddress() const;
 
@@ -68,9 +68,9 @@ namespace log4cxx
                 private:
                         Socket(const Socket&);
                         Socket& operator=(const Socket&);
-                        
+
                         Pool pool;
-                        
+
                         apr_socket_t* socket;
 
 
@@ -81,9 +81,9 @@ namespace log4cxx
                         this socket is connected. */
                         int port;
                 };
-                
+
                 LOG4CXX_PTR_DEF(Socket);
-                
+
         } // namespace helpers
 } // namespace log4cxx
 

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/socketoutputstream.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/socketoutputstream.h b/src/main/include/log4cxx/helpers/socketoutputstream.h
index 0c6fbb4..94d9895 100644
--- a/src/main/include/log4cxx/helpers/socketoutputstream.h
+++ b/src/main/include/log4cxx/helpers/socketoutputstream.h
@@ -59,9 +59,9 @@ namespace log4cxx
                        SocketOutputStream& operator=(const SocketOutputStream&);
 
                 };
-                
+
                 LOG4CXX_PTR_DEF(SocketOutputStream);
-                
+
         }  // namespace helpers
 } // namespace log4cxx
 

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/systemoutwriter.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/systemoutwriter.h b/src/main/include/log4cxx/helpers/systemoutwriter.h
index af7c55b..9838e71 100644
--- a/src/main/include/log4cxx/helpers/systemoutwriter.h
+++ b/src/main/include/log4cxx/helpers/systemoutwriter.h
@@ -38,11 +38,11 @@ namespace log4cxx
 
                   SystemOutWriter();
                   ~SystemOutWriter();
-                  
+
                   virtual void close(Pool& p);
                   virtual void flush(Pool& p);
                   virtual void write(const LogString& str, Pool& p);
-                  
+
                   static void write(const LogString& str);
                   static void flush();
         private:

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/thread.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/thread.h b/src/main/include/log4cxx/helpers/thread.h
index ca5f44b..880e07d 100644
--- a/src/main/include/log4cxx/helpers/thread.h
+++ b/src/main/include/log4cxx/helpers/thread.h
@@ -83,11 +83,11 @@ namespace log4cxx
                          */
                         static void sleep(int millis);
                         /**
-                         *  Sets interrupted status for current thread to true.  
+                         *  Sets interrupted status for current thread to true.
                          */
                         static void currentThreadInterrupt();
                         /**
-                         *  Sets interrupted status to true.  
+                         *  Sets interrupted status to true.
                          */
                         void interrupt();
                         /**
@@ -95,11 +95,11 @@ namespace log4cxx
                          *  sets the interrupted status to false.
                          */
                         static bool interrupted();
-                        
+
                         bool isAlive();
                         bool isCurrentThread() const;
                         void ending();
-                        
+
 
                 private:
                         Pool p;
@@ -110,7 +110,7 @@ namespace log4cxx
                         apr_thread_cond_t* interruptedCondition;
                         Thread(const Thread&);
                         Thread& operator=(const Thread&);
-                        friend void* LOG4CXX_THREAD_FUNC ThreadLaunch::launcher(apr_thread_t* thread, void* data); 
+                        friend void* LOG4CXX_THREAD_FUNC ThreadLaunch::launcher(apr_thread_t* thread, void* data);
                 };
         } // namespace helpers
 } // namespace log4cxx

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/threadlocal.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/threadlocal.h b/src/main/include/log4cxx/helpers/threadlocal.h
index 9275811..c4985af 100644
--- a/src/main/include/log4cxx/helpers/threadlocal.h
+++ b/src/main/include/log4cxx/helpers/threadlocal.h
@@ -57,23 +57,23 @@ namespace log4cxx
                      *  Sets the value in the current thread's copy of this thread-local variable.
                      *  @param priv new value.
                      */
-                    void set(void* priv);                    
+                    void set(void* priv);
                     /**
                      *  Returns the value in the current thread's copy of this thread-local variable.
                      *  @return value of thread-local variable for the current thread.
                      */
                     void* get();
-               
+
                 private:
                     /**
                      * Prevent use of default copy constructor.
                      */
                      ThreadLocal(const ThreadLocal&);
                     /**
-                     *   Prevent use of default assignment operator.  
+                     *   Prevent use of default assignment operator.
                      */
                      ThreadLocal& operator=(const ThreadLocal&);
-                     
+
                      static apr_threadkey_t* create(Pool& p);
 
                 Pool p;

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/threadspecificdata.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/threadspecificdata.h b/src/main/include/log4cxx/helpers/threadspecificdata.h
index b02cf51..04fe098 100644
--- a/src/main/include/log4cxx/helpers/threadspecificdata.h
+++ b/src/main/include/log4cxx/helpers/threadspecificdata.h
@@ -45,14 +45,14 @@ namespace log4cxx
                          *  Release this ThreadSpecficData if empty.
                          */
                         void recycle();
-                        
+
                         static void put(const LogString& key, const LogString& val);
                         static void push(const LogString& val);
                         static void inherit(const log4cxx::NDC::Stack& stack);
-                        
+
                         log4cxx::NDC::Stack& getStack();
                         log4cxx::MDC::Map& getMap();
-                        
+
 
                 private:
                         static ThreadSpecificData& getDataNoThreads();

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/helpers/transcoder.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/helpers/transcoder.h b/src/main/include/log4cxx/helpers/transcoder.h
index 0559ba9..4336518 100644
--- a/src/main/include/log4cxx/helpers/transcoder.h
+++ b/src/main/include/log4cxx/helpers/transcoder.h
@@ -39,7 +39,7 @@ namespace log4cxx {
       class LOG4CXX_EXPORT Transcoder {
       public:
 
-      
+
       /**
        *   Appends this specified string of UTF-8 characters to LogString.
        */
@@ -64,7 +64,7 @@ namespace log4cxx {
        *    Append UCS-4 code point to a byte buffer as UTF-16BE.
        */
       static void encodeUTF16BE(unsigned int sv, ByteBuffer& dst);
-      
+
 
       /**
        *   Decodes next character from a UTF-8 string.
@@ -90,14 +90,14 @@ namespace log4cxx {
       static void decode(const std::string& src, LogString& dst);
       /**
        *     Appends a LogString to a string in the current
-       *        code-page.  Unrepresentable characters may be 
+       *        code-page.  Unrepresentable characters may be
        *        replaced with loss characters.
       */
       static void encode(const LogString& src, std::string& dst);
 
       /**
         *     Encodes the specified LogString to the current
-        *       character set. 
+        *       character set.
         *      @param src string to encode.
         *      @param p pool from which to allocate return value.
         *      @return pool allocated string.
@@ -134,7 +134,7 @@ namespace log4cxx {
 #if LOG4CXX_UNICHAR_API || LOG4CXX_CFSTRING_API || LOG4CXX_LOGCHAR_IS_UNICHAR
       static void decode(const std::basic_string<UniChar>& src, LogString& dst);
       static void encode(const LogString& src, std::basic_string<UniChar>& dst);
-      
+
       /**
        *   Decodes next character from a UniChar string.
        *   @param in string from which the character is extracted.
@@ -160,7 +160,7 @@ namespace log4cxx {
 #endif
 
       enum { LOSSCHAR = 0x3F };
-      
+
       /**
        *   Returns a logchar value given a character literal in the ASCII charset.
        *   Used to implement the LOG4CXX_STR macro for EBCDIC and UNICHAR.
@@ -173,7 +173,7 @@ namespace log4cxx {
       static LogString decode(const char* v);
 
       /**
-       *   Encodes a charset name in the default encoding 
+       *   Encodes a charset name in the default encoding
        *      without using a CharsetEncoder (which could trigger recursion).
        */
       static std::string encodeCharsetName(const LogString& charsetName);
@@ -188,7 +188,7 @@ namespace log4cxx {
       static size_t encodeUTF8(unsigned int ch, char* dst);
       static size_t encodeUTF16BE(unsigned int ch, char* dst);
       static size_t encodeUTF16LE(unsigned int ch, char* dst);
-      
+
       };
    }
 }

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/layout.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/layout.h b/src/main/include/log4cxx/layout.h
index b07d650..22ca17e 100644
--- a/src/main/include/log4cxx/layout.h
+++ b/src/main/include/log4cxx/layout.h
@@ -45,7 +45,7 @@ namespace log4cxx
                         LOG4CXX_CAST_ENTRY(Layout)
                         LOG4CXX_CAST_ENTRY(spi::OptionHandler)
                 END_LOG4CXX_CAST_MAP()
-    
+
                 virtual ~Layout();
                 void addRef() const;
                 void releaseRef() const;

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/logmanager.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/logmanager.h b/src/main/include/log4cxx/logmanager.h
index b9ec0b6..a1e2448 100644
--- a/src/main/include/log4cxx/logmanager.h
+++ b/src/main/include/log4cxx/logmanager.h
@@ -40,8 +40,8 @@ namespace log4cxx
 
     /**
     * Use the <code>LogManager</code> class to retreive Logger
-    * instances or to operate on the current 
-    * {@link log4cxx::spi::LoggerRepository LoggerRepository}. 
+    * instances or to operate on the current
+    * {@link log4cxx::spi::LoggerRepository LoggerRepository}.
     * When the <code>LogManager</code> class is loaded
     * into memory the default initialization procedure is inititated.
         */

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/logstring.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/logstring.h b/src/main/include/log4cxx/logstring.h
index 19e8aec..297b76d 100644
--- a/src/main/include/log4cxx/logstring.h
+++ b/src/main/include/log4cxx/logstring.h
@@ -54,14 +54,14 @@ typedef unsigned short UniChar;
    typedef char logchar;
 #if LOG4CXX_CHARSET_EBCDIC
 #define LOG4CXX_STR(str) log4cxx::helpers::Transcoder::decode(str)
-#else   
+#else
 #define LOG4CXX_STR(str) str
 #endif
 #endif
 
 #if LOG4CXX_LOGCHAR_IS_UNICHAR
    typedef UniChar logchar;
-#define LOG4CXX_STR(str) log4cxx::helpers::Transcoder::decode(str)   
+#define LOG4CXX_STR(str) log4cxx::helpers::Transcoder::decode(str)
 #endif
 
    typedef std::basic_string<logchar> LogString;

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/ndc.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/ndc.h b/src/main/include/log4cxx/ndc.h
index 7cf7128..0791d03 100644
--- a/src/main/include/log4cxx/ndc.h
+++ b/src/main/include/log4cxx/ndc.h
@@ -104,7 +104,7 @@ namespace log4cxx
                  Creates a nested diagnostic context.
                  Since java performs no automatic cleanup of objects when a
                  scope is left, in log4j push() and pop() must be used
-                 to manage the NDC. For convenience, log4cxx provides 
+                 to manage the NDC. For convenience, log4cxx provides
                  an NDC constructor and destructor which simply call the push() and
                  pop() methods, allowing for automatic cleanup when the current
                  scope ends.
@@ -233,13 +233,13 @@ namespace log4cxx
                 memory.
                 */
                 static void remove();
-                
+
 #if LOG4CXX_WCHAR_T_API
                /**
                  Creates a nested diagnostic context.
                  Since java performs no automatic cleanup of objects when a
                  scope is left, in log4j push() and pop() must be used
-                 to manage the NDC. For convenience, log4cxx provides 
+                 to manage the NDC. For convenience, log4cxx provides
                  an NDC constructor and destructor which simply call the push() and
                  pop() methods, allowing for automatic cleanup when the current
                  scope ends.
@@ -258,13 +258,13 @@ namespace log4cxx
                 /**
                  *   Appends the current NDC content to the provided string.
                  *   @param dst destination.
-                 *   @return true if NDC value set. 
+                 *   @return true if NDC value set.
                  */
                 static bool peek(std::wstring& dst);
                 /**
                  *   Appends the current NDC content to the provided string and removes the value from the NDC.
                  *   @param dst destination.
-                 *   @return true if NDC value set. 
+                 *   @return true if NDC value set.
                  */
                 static bool pop(std::wstring& dst);
 #endif
@@ -273,7 +273,7 @@ namespace log4cxx
                  Creates a nested diagnostic context.
                  Since java performs no automatic cleanup of objects when a
                  scope is left, in log4j push() and pop() must be used
-                 to manage the NDC. For convenience, log4cxx provides 
+                 to manage the NDC. For convenience, log4cxx provides
                  an NDC constructor and destructor which simply call the push() and
                  pop() methods, allowing for automatic cleanup when the current
                  scope ends.
@@ -292,13 +292,13 @@ namespace log4cxx
                 /**
                  *   Appends the current NDC content to the provided string.
                  *   @param dst destination.
-                 *   @return true if NDC value set. 
+                 *   @return true if NDC value set.
                  */
                 static bool peek(std::basic_string<UniChar>& dst);
                 /**
                  *   Appends the current NDC content to the provided string and removes the value from the NDC.
                  *   @param dst destination.
-                 *   @return true if NDC value set. 
+                 *   @return true if NDC value set.
                  */
                 static bool pop(std::basic_string<UniChar>& dst);
 #endif
@@ -307,7 +307,7 @@ namespace log4cxx
                  Creates a nested diagnostic context.
                  Since java performs no automatic cleanup of objects when a
                  scope is left, in log4j push() and pop() must be used
-                 to manage the NDC. For convenience, log4cxx provides 
+                 to manage the NDC. For convenience, log4cxx provides
                  an NDC constructor and destructor which simply call the push() and
                  pop() methods, allowing for automatic cleanup when the current
                  scope ends.
@@ -326,17 +326,17 @@ namespace log4cxx
                 /**
                  *   Gets the current NDC value.
                  *   @param dst destination.
-                 *   @return true if NDC value set. 
+                 *   @return true if NDC value set.
                  */
                 static bool peek(CFStringRef& dst);
                 /**
                  *  Gets and removes the current NDC value.
                  *   @param dst destination.
-                 *   @return true if NDC value set. 
+                 *   @return true if NDC value set.
                  */
                 static bool pop(CFStringRef& dst);
 #endif
-                
+
         private:
                 NDC(const NDC&);
                 NDC& operator=(const NDC&);

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/net/smtpappender.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/net/smtpappender.h b/src/main/include/log4cxx/net/smtpappender.h
index eb1dbb5..adac446 100644
--- a/src/main/include/log4cxx/net/smtpappender.h
+++ b/src/main/include/log4cxx/net/smtpappender.h
@@ -241,17 +241,17 @@ namespace log4cxx
                         inline int getBufferSize() const
                                 { return bufferSize; }
 
-                   
+
                         /**
                          *   Gets the current triggering evaluator.
                          *   @return triggering evaluator.
-                         */     
+                         */
                         log4cxx::spi::TriggeringEventEvaluatorPtr getEvaluator() const;
 
                         /**
                          *   Sets the triggering evaluator.
                          *   @param trigger triggering evaluator.
-                         */     
+                         */
                         void setEvaluator(log4cxx::spi::TriggeringEventEvaluatorPtr& trigger);
 
                         /**
@@ -262,7 +262,7 @@ namespace log4cxx
                         for the SMTPAppender.
                         */
                         void setEvaluatorClass(const LogString& value);
-                 
+
                         /**
                         The <b>LocationInfo</b> option is provided for compatibility with log4j
                         and has no effect in log4cxx.
@@ -274,8 +274,8 @@ namespace log4cxx
                         */
                         bool getLocationInfo() const;
                 }; // class SMTPAppender
-                
-                LOG4CXX_PTR_DEF(SMTPAppender);                
+
+                LOG4CXX_PTR_DEF(SMTPAppender);
 
         }  // namespace net
 } // namespace log4cxx

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/net/socketappenderskeleton.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/net/socketappenderskeleton.h b/src/main/include/log4cxx/net/socketappenderskeleton.h
index fd0bfa7..0f6a896 100644
--- a/src/main/include/log4cxx/net/socketappenderskeleton.h
+++ b/src/main/include/log4cxx/net/socketappenderskeleton.h
@@ -67,7 +67,7 @@ namespace log4cxx
                 Connect to the specified <b>RemoteHost</b> and <b>Port</b>.
                 */
                 void activateOptions(log4cxx::helpers::Pool& p);
-                
+
                 void close();
 
 
@@ -147,11 +147,11 @@ namespace log4cxx
            protected:
 
                 virtual void setSocket(log4cxx::helpers::SocketPtr& socket, log4cxx::helpers::Pool& p) = 0;
-                
+
                 virtual void cleanUp(log4cxx::helpers::Pool& p) = 0;
-                
+
                 virtual int getDefaultDelay() const = 0;
-                
+
                 virtual int getDefaultPort() const = 0;
 
            private:

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/net/telnetappender.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/net/telnetappender.h b/src/main/include/log4cxx/net/telnetappender.h
index 861728c..fbc00e0 100644
--- a/src/main/include/log4cxx/net/telnetappender.h
+++ b/src/main/include/log4cxx/net/telnetappender.h
@@ -91,10 +91,10 @@ servlet.
                         attached client(s). */
                         virtual bool requiresLayout() const
                                 { return true; }
-                                
+
                         LogString getEncoding() const;
                         void setEncoding(const LogString& value);
-        
+
 
                         /** all of the options have been set, create the socket handler and
                         wait for connections. */
@@ -144,7 +144,7 @@ servlet.
                         size_t activeConnections;
                         static void* LOG4CXX_THREAD_FUNC acceptConnections(apr_thread_t* thread, void* data);
                 }; // class TelnetAppender
-                
+
                 LOG4CXX_PTR_DEF(TelnetAppender);
     } // namespace net
 } // namespace log4cxx

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/pattern/classnamepatternconverter.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/pattern/classnamepatternconverter.h b/src/main/include/log4cxx/pattern/classnamepatternconverter.h
index 6ce1af7..8c3b2f2 100644
--- a/src/main/include/log4cxx/pattern/classnamepatternconverter.h
+++ b/src/main/include/log4cxx/pattern/classnamepatternconverter.h
@@ -28,8 +28,8 @@ namespace log4cxx {
 /**
  * Formats the class name of the site of the logging request.
  *
- * 
- * 
+ *
+ *
  */
 class LOG4CXX_EXPORT ClassNamePatternConverter : public NamePatternConverter {
   /**

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/pattern/datepatternconverter.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/pattern/datepatternconverter.h b/src/main/include/log4cxx/pattern/datepatternconverter.h
index cdaef42..978ee8e 100644
--- a/src/main/include/log4cxx/pattern/datepatternconverter.h
+++ b/src/main/include/log4cxx/pattern/datepatternconverter.h
@@ -30,8 +30,8 @@ namespace log4cxx {
 /**
  * Convert and format the event's date in a StringBuffer.
  *
- * 
- * 
+ *
+ *
  */
 class LOG4CXX_EXPORT DatePatternConverter : public LoggingEventPatternConverter {
   /**

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/pattern/filedatepatternconverter.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/pattern/filedatepatternconverter.h b/src/main/include/log4cxx/pattern/filedatepatternconverter.h
index 9e15239..30893ec 100644
--- a/src/main/include/log4cxx/pattern/filedatepatternconverter.h
+++ b/src/main/include/log4cxx/pattern/filedatepatternconverter.h
@@ -28,8 +28,8 @@ namespace log4cxx { namespace pattern {
  * date pattern for a %d specifier in a file name is different than
  * the %d pattern in pattern layout.
  *
- * 
- * 
+ *
+ *
  */
 class LOG4CXX_EXPORT FileDatePatternConverter {
   /**

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/pattern/filelocationpatternconverter.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/pattern/filelocationpatternconverter.h b/src/main/include/log4cxx/pattern/filelocationpatternconverter.h
index 0d54de2..b2d14d6 100644
--- a/src/main/include/log4cxx/pattern/filelocationpatternconverter.h
+++ b/src/main/include/log4cxx/pattern/filelocationpatternconverter.h
@@ -27,8 +27,8 @@ namespace log4cxx {
 /**
  * Return the event's line location information in a StringBuffer.
  *
- * 
- * 
+ *
+ *
  */
 class LOG4CXX_EXPORT FileLocationPatternConverter
   : public LoggingEventPatternConverter {

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/pattern/formattinginfo.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/pattern/formattinginfo.h b/src/main/include/log4cxx/pattern/formattinginfo.h
index c3eac5a..8b1ab1d 100644
--- a/src/main/include/log4cxx/pattern/formattinginfo.h
+++ b/src/main/include/log4cxx/pattern/formattinginfo.h
@@ -34,9 +34,9 @@ typedef helpers::ObjectPtrT<FormattingInfo> FormattingInfoPtr;
  * Modifies the output of a pattern converter for a specified minimum
  * and maximum width and alignment.
  *
- *  
  *
- *  
+ *
+ *
  */
 class LOG4CXX_EXPORT FormattingInfo : public virtual log4cxx::helpers::ObjectImpl {
 

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/pattern/fulllocationpatternconverter.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/pattern/fulllocationpatternconverter.h b/src/main/include/log4cxx/pattern/fulllocationpatternconverter.h
index c08d435..1b54fa9 100644
--- a/src/main/include/log4cxx/pattern/fulllocationpatternconverter.h
+++ b/src/main/include/log4cxx/pattern/fulllocationpatternconverter.h
@@ -27,8 +27,8 @@ namespace pattern {
 /**
  * Format the event's line location information.
  *
- * 
- * 
+ *
+ *
  */
 class LOG4CXX_EXPORT FullLocationPatternConverter
   : public LoggingEventPatternConverter {

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/pattern/integerpatternconverter.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/pattern/integerpatternconverter.h b/src/main/include/log4cxx/pattern/integerpatternconverter.h
index 0667809..c552632 100644
--- a/src/main/include/log4cxx/pattern/integerpatternconverter.h
+++ b/src/main/include/log4cxx/pattern/integerpatternconverter.h
@@ -26,8 +26,8 @@ namespace log4cxx { namespace pattern {
 /**
  * Formats an integer.
  *
- * 
- * 
+ *
+ *
  */
 class LOG4CXX_EXPORT IntegerPatternConverter : public PatternConverter {
 

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/pattern/levelpatternconverter.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/pattern/levelpatternconverter.h b/src/main/include/log4cxx/pattern/levelpatternconverter.h
index 5a9cbe9..5ff198d 100644
--- a/src/main/include/log4cxx/pattern/levelpatternconverter.h
+++ b/src/main/include/log4cxx/pattern/levelpatternconverter.h
@@ -26,8 +26,8 @@ namespace log4cxx { namespace pattern {
 /**
  * Return the event's level in a StringBuffer.
  *
- * 
- * 
+ *
+ *
  */
 class LOG4CXX_EXPORT LevelPatternConverter : public LoggingEventPatternConverter {
   /**

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/pattern/linelocationpatternconverter.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/pattern/linelocationpatternconverter.h b/src/main/include/log4cxx/pattern/linelocationpatternconverter.h
index f1cbfe4..adacfdc 100644
--- a/src/main/include/log4cxx/pattern/linelocationpatternconverter.h
+++ b/src/main/include/log4cxx/pattern/linelocationpatternconverter.h
@@ -27,8 +27,8 @@ namespace pattern {
 /**
  * Format the event's line location information.
  *
- * 
- * 
+ *
+ *
  */
 class LOG4CXX_EXPORT LineLocationPatternConverter
   : public LoggingEventPatternConverter {

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/pattern/lineseparatorpatternconverter.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/pattern/lineseparatorpatternconverter.h b/src/main/include/log4cxx/pattern/lineseparatorpatternconverter.h
index 9781e5b..85f5633 100644
--- a/src/main/include/log4cxx/pattern/lineseparatorpatternconverter.h
+++ b/src/main/include/log4cxx/pattern/lineseparatorpatternconverter.h
@@ -27,8 +27,8 @@ namespace pattern {
 /**
  * Formats a line separator.
  *
- * 
- * 
+ *
+ *
  */
 class LOG4CXX_EXPORT LineSeparatorPatternConverter
   : public LoggingEventPatternConverter {

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/pattern/literalpatternconverter.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/pattern/literalpatternconverter.h b/src/main/include/log4cxx/pattern/literalpatternconverter.h
index 5d24434..3717f43 100644
--- a/src/main/include/log4cxx/pattern/literalpatternconverter.h
+++ b/src/main/include/log4cxx/pattern/literalpatternconverter.h
@@ -26,8 +26,8 @@ namespace log4cxx {
 /**
  * Formats a string literal.
  *
- * 
- * 
+ *
+ *
  *
  */
 class LOG4CXX_EXPORT LiteralPatternConverter : public LoggingEventPatternConverter {

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/pattern/loggerpatternconverter.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/pattern/loggerpatternconverter.h b/src/main/include/log4cxx/pattern/loggerpatternconverter.h
index d707fd1..76b8561 100644
--- a/src/main/include/log4cxx/pattern/loggerpatternconverter.h
+++ b/src/main/include/log4cxx/pattern/loggerpatternconverter.h
@@ -27,9 +27,9 @@ namespace log4cxx {
 /**
  * Formats a logger name.
  *
- * 
  *
- * 
+ *
+ *
  */
 class LOG4CXX_EXPORT LoggerPatternConverter : public NamePatternConverter {
 

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/pattern/loggingeventpatternconverter.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/pattern/loggingeventpatternconverter.h b/src/main/include/log4cxx/pattern/loggingeventpatternconverter.h
index 7118808..048366c 100644
--- a/src/main/include/log4cxx/pattern/loggingeventpatternconverter.h
+++ b/src/main/include/log4cxx/pattern/loggingeventpatternconverter.h
@@ -28,9 +28,9 @@ namespace log4cxx {
     * LoggingEventPatternConverter is a base class for pattern converters
     * that can format information from instances of LoggingEvent.
     *
-    * 
     *
-    * 
+    *
+    *
     */
 class LOG4CXX_EXPORT LoggingEventPatternConverter : public PatternConverter {
 protected:

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/pattern/messagepatternconverter.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/pattern/messagepatternconverter.h b/src/main/include/log4cxx/pattern/messagepatternconverter.h
index 14a9fe2..4bb86ef 100644
--- a/src/main/include/log4cxx/pattern/messagepatternconverter.h
+++ b/src/main/include/log4cxx/pattern/messagepatternconverter.h
@@ -26,8 +26,8 @@ namespace log4cxx { namespace pattern {
 /**
  * Formats the message of an logging event.
  *
- * 
- * 
+ *
+ *
  */
 class LOG4CXX_EXPORT MessagePatternConverter : public LoggingEventPatternConverter {
 

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/pattern/methodlocationpatternconverter.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/pattern/methodlocationpatternconverter.h b/src/main/include/log4cxx/pattern/methodlocationpatternconverter.h
index 818af2c..8cbc6b1 100644
--- a/src/main/include/log4cxx/pattern/methodlocationpatternconverter.h
+++ b/src/main/include/log4cxx/pattern/methodlocationpatternconverter.h
@@ -26,8 +26,8 @@ namespace log4cxx { namespace pattern {
 /**
  * Return the event's line location information in a StringBuffer.
  *
- * 
- * 
+ *
+ *
  */
 class LOG4CXX_EXPORT MethodLocationPatternConverter
   : public LoggingEventPatternConverter {

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/pattern/nameabbreviator.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/pattern/nameabbreviator.h b/src/main/include/log4cxx/pattern/nameabbreviator.h
index 8eedaab..092ee12 100644
--- a/src/main/include/log4cxx/pattern/nameabbreviator.h
+++ b/src/main/include/log4cxx/pattern/nameabbreviator.h
@@ -31,8 +31,8 @@ namespace log4cxx {
 /**
  * NameAbbreviator generates abbreviated logger and class names.
  *
- * 
- * 
+ *
+ *
  */
 class LOG4CXX_EXPORT NameAbbreviator : public log4cxx::helpers::ObjectImpl {
 public:

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/pattern/ndcpatternconverter.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/pattern/ndcpatternconverter.h b/src/main/include/log4cxx/pattern/ndcpatternconverter.h
index fd49dce..ce026fd 100644
--- a/src/main/include/log4cxx/pattern/ndcpatternconverter.h
+++ b/src/main/include/log4cxx/pattern/ndcpatternconverter.h
@@ -26,8 +26,8 @@ namespace log4cxx { namespace pattern {
 /**
  * Return the event's NDC in a StringBuffer.
  *
- * 
- * 
+ *
+ *
  */
 class LOG4CXX_EXPORT NDCPatternConverter : public LoggingEventPatternConverter {
 

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/pattern/patternparser.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/pattern/patternparser.h b/src/main/include/log4cxx/pattern/patternparser.h
index 2a5113a..eab174b 100644
--- a/src/main/include/log4cxx/pattern/patternparser.h
+++ b/src/main/include/log4cxx/pattern/patternparser.h
@@ -49,7 +49,7 @@ typedef std::map<LogString, PatternConstructor> PatternMap;
  * <p>It is this class that parses conversion patterns and creates
  * a chained list of {@link PatternConverter PatternConverters}.
  *
- * 
+ *
 */
 class LOG4CXX_EXPORT PatternParser {
   /**

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/pattern/propertiespatternconverter.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/pattern/propertiespatternconverter.h b/src/main/include/log4cxx/pattern/propertiespatternconverter.h
index 9e59a1a..9dcad0c 100644
--- a/src/main/include/log4cxx/pattern/propertiespatternconverter.h
+++ b/src/main/include/log4cxx/pattern/propertiespatternconverter.h
@@ -30,8 +30,8 @@ namespace log4cxx { namespace pattern {
  * within the property bundle
  * when this pattern converter has the option set.
  *
- * 
- * 
+ *
+ *
  */
 class LOG4CXX_EXPORT PropertiesPatternConverter
   : public LoggingEventPatternConverter {

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/pattern/relativetimepatternconverter.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/pattern/relativetimepatternconverter.h b/src/main/include/log4cxx/pattern/relativetimepatternconverter.h
index 385fc41..708fe8f 100644
--- a/src/main/include/log4cxx/pattern/relativetimepatternconverter.h
+++ b/src/main/include/log4cxx/pattern/relativetimepatternconverter.h
@@ -26,8 +26,8 @@ namespace log4cxx { namespace pattern {
 /**
  * Format the relative time in milliseconds.
  *
- * 
- * 
+ *
+ *
  */
 class LOG4CXX_EXPORT RelativeTimePatternConverter : public LoggingEventPatternConverter {
 public:

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/pattern/threadpatternconverter.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/pattern/threadpatternconverter.h b/src/main/include/log4cxx/pattern/threadpatternconverter.h
index f9216b9..178f652 100644
--- a/src/main/include/log4cxx/pattern/threadpatternconverter.h
+++ b/src/main/include/log4cxx/pattern/threadpatternconverter.h
@@ -26,8 +26,8 @@ namespace log4cxx { namespace pattern {
 /**
  * Formats the event thread name.
  *
- * 
- * 
+ *
+ *
  */
 class LOG4CXX_EXPORT ThreadPatternConverter : public LoggingEventPatternConverter {
   /**

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/pattern/throwableinformationpatternconverter.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/pattern/throwableinformationpatternconverter.h b/src/main/include/log4cxx/pattern/throwableinformationpatternconverter.h
index cd4f415..e3a4805 100644
--- a/src/main/include/log4cxx/pattern/throwableinformationpatternconverter.h
+++ b/src/main/include/log4cxx/pattern/throwableinformationpatternconverter.h
@@ -27,8 +27,8 @@ namespace log4cxx { namespace pattern {
  * Outputs the ThrowableInformation portion of the LoggingiEvent as a full stacktrace
  * unless this converter's option is 'short', where it just outputs the first line of the trace.
  *
- * 
- * 
+ *
+ *
  *
  */
 class LOG4CXX_EXPORT ThrowableInformationPatternConverter

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/propertyconfigurator.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/propertyconfigurator.h b/src/main/include/log4cxx/propertyconfigurator.h
index a45bfa6..e9706ff 100644
--- a/src/main/include/log4cxx/propertyconfigurator.h
+++ b/src/main/include/log4cxx/propertyconfigurator.h
@@ -381,7 +381,7 @@ protected:
 
       void registryPut(const AppenderPtr& appender);
       AppenderPtr registryGet(const LogString& name);
-      
+
 private:
       PropertyConfigurator(const PropertyConfigurator&);
       PropertyConfigurator& operator=(const PropertyConfigurator&);

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/provisionnode.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/provisionnode.h b/src/main/include/log4cxx/provisionnode.h
index 5d1c31f..c6ec36f 100644
--- a/src/main/include/log4cxx/provisionnode.h
+++ b/src/main/include/log4cxx/provisionnode.h
@@ -5,16 +5,16 @@
  * 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 _LOG4CXX_PROVISION_NODE_H
 #define _LOG4CXX_PROVISION_NODE_H
 
@@ -27,7 +27,7 @@ namespace log4cxx
     class Logger;
     typedef helpers::ObjectPtrT<Logger> LoggerPtr;
 
-    
+
     typedef std::vector<LoggerPtr> ProvisionNode;
 
 }  // namespace log4cxx

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/rolling/filterbasedtriggeringpolicy.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/rolling/filterbasedtriggeringpolicy.h b/src/main/include/log4cxx/rolling/filterbasedtriggeringpolicy.h
index efe5825..310edd6 100644
--- a/src/main/include/log4cxx/rolling/filterbasedtriggeringpolicy.h
+++ b/src/main/include/log4cxx/rolling/filterbasedtriggeringpolicy.h
@@ -38,8 +38,8 @@
  * by evaluating the current message against a set of filters.  Unless a
  * filter rejects a message, a rolling event will be triggered.
  *
- * 
- * 
+ *
+ *
  *
  */
 class LOG4CXX_EXPORT FilterBasedTriggeringPolicy : public TriggeringPolicy {

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/rolling/manualtriggeringpolicy.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/rolling/manualtriggeringpolicy.h b/src/main/include/log4cxx/rolling/manualtriggeringpolicy.h
index 5461183..cb29794 100644
--- a/src/main/include/log4cxx/rolling/manualtriggeringpolicy.h
+++ b/src/main/include/log4cxx/rolling/manualtriggeringpolicy.h
@@ -34,7 +34,7 @@ namespace log4cxx {
          * ManualTriggeringPolicy only rolls over on explicit calls to
          * RollingFileAppender.rollover().
          *
-         * 
+         *
          *
          */
         class LOG4CXX_EXPORT ManualTriggeringPolicy : public TriggeringPolicy {

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/rolling/rollingfileappender.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/rolling/rollingfileappender.h b/src/main/include/log4cxx/rolling/rollingfileappender.h
index ec044fb..103e967 100644
--- a/src/main/include/log4cxx/rolling/rollingfileappender.h
+++ b/src/main/include/log4cxx/rolling/rollingfileappender.h
@@ -24,7 +24,7 @@
 namespace log4cxx {
     namespace rolling {
 
-        
+
         /**
          * <code>RollingFileAppender</code> extends {@link log4cxx::FileAppender} to backup the log files
          * depending on {@link log4cxx::rolling::RollingPolicy RollingPolicy} and {@link log4cxx::rolling::TriggeringPolicy TriggeringPolicy}.
@@ -66,9 +66,9 @@ namespace log4cxx {
          * automatic compression of the archived files. See
          * {@link TimeBasedRollingPolicy} for more details.
          *
-         * 
-         * 
-         * 
+         *
+         *
+         *
          * */
         class LOG4CXX_EXPORT RollingFileAppender : public RollingFileAppenderSkeleton {
           DECLARE_LOG4CXX_OBJECT(RollingFileAppender)

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/rolling/rollingfileappenderskeleton.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/rolling/rollingfileappenderskeleton.h b/src/main/include/log4cxx/rolling/rollingfileappenderskeleton.h
index 328fc38..40568c7 100644
--- a/src/main/include/log4cxx/rolling/rollingfileappenderskeleton.h
+++ b/src/main/include/log4cxx/rolling/rollingfileappenderskeleton.h
@@ -32,8 +32,8 @@ namespace log4cxx {
         /**
          *  Base class for log4cxx::rolling::RollingFileAppender and log4cxx::RollingFileAppender
          * (analogues of org.apache.log4j.rolling.RFA from extras companion and
-         *  org.apache.log4j.RFA from log4j 1.2, respectively). 
-         * 
+         *  org.apache.log4j.RFA from log4j 1.2, respectively).
+         *
          * */
         class LOG4CXX_EXPORT RollingFileAppenderSkeleton : public FileAppender {
           DECLARE_LOG4CXX_OBJECT(RollingFileAppenderSkeleton)
@@ -137,7 +137,7 @@ namespace log4cxx {
            * @return byte length of current active log file.
            */
           size_t getFileLength() const;
-          
+
 #ifdef LOG4CXX_MULTI_PROCESS
           /**
            * Set byte length of current active log file.
@@ -164,7 +164,7 @@ namespace log4cxx {
           void incrementFileLength(size_t increment);
 
         };
-        
+
 
         LOG4CXX_PTR_DEF(RollingFileAppenderSkeleton);
 

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/rolling/rollingpolicybase.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/rolling/rollingpolicybase.h b/src/main/include/log4cxx/rolling/rollingpolicybase.h
index 50b69a6..4011a62 100644
--- a/src/main/include/log4cxx/rolling/rollingpolicybase.h
+++ b/src/main/include/log4cxx/rolling/rollingpolicybase.h
@@ -41,8 +41,8 @@ namespace log4cxx {
          * Implements methods common to most, it not all, rolling
          * policies.
          *
-         * 
-         * 
+         *
+         *
          */
         class LOG4CXX_EXPORT RollingPolicyBase :
            public virtual RollingPolicy,
@@ -96,7 +96,7 @@ namespace log4cxx {
            LogString getFileNamePattern() const;
 
 
-#ifdef LOG4CXX_MULTI_PROCESS                
+#ifdef LOG4CXX_MULTI_PROCESS
            PatternConverterList getPatternConverterList() { return patternConverters; }
 #endif
            protected:

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/rolling/sizebasedtriggeringpolicy.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/rolling/sizebasedtriggeringpolicy.h b/src/main/include/log4cxx/rolling/sizebasedtriggeringpolicy.h
index 87ddffb..918d691 100644
--- a/src/main/include/log4cxx/rolling/sizebasedtriggeringpolicy.h
+++ b/src/main/include/log4cxx/rolling/sizebasedtriggeringpolicy.h
@@ -34,7 +34,7 @@ namespace log4cxx {
          * SizeBasedTriggeringPolicy looks at size of the file being
          * currently written to.
          *
-         * 
+         *
          *
          */
         class LOG4CXX_EXPORT SizeBasedTriggeringPolicy : public TriggeringPolicy {

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/rolling/triggeringpolicy.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/rolling/triggeringpolicy.h b/src/main/include/log4cxx/rolling/triggeringpolicy.h
index 6a71632..7b53ef2 100644
--- a/src/main/include/log4cxx/rolling/triggeringpolicy.h
+++ b/src/main/include/log4cxx/rolling/triggeringpolicy.h
@@ -35,8 +35,8 @@ namespace log4cxx {
          * occurs. Such conditions include time of day, file size, an
          * external event or a combination thereof.
          *
-         * 
-         * 
+         *
+         *
          * */
 
         class LOG4CXX_EXPORT TriggeringPolicy :

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/rolling/zipcompressaction.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/rolling/zipcompressaction.h b/src/main/include/log4cxx/rolling/zipcompressaction.h
index 66a19c6..559326b 100644
--- a/src/main/include/log4cxx/rolling/zipcompressaction.h
+++ b/src/main/include/log4cxx/rolling/zipcompressaction.h
@@ -62,7 +62,7 @@ namespace log4cxx {
         };
 
         LOG4CXX_PTR_DEF(ZipCompressAction);
-        
+
     }
 
 #if defined(_MSC_VER)

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/spi/appenderattachable.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/spi/appenderattachable.h b/src/main/include/log4cxx/spi/appenderattachable.h
index 7fa06fa..bd49f0d 100644
--- a/src/main/include/log4cxx/spi/appenderattachable.h
+++ b/src/main/include/log4cxx/spi/appenderattachable.h
@@ -86,7 +86,7 @@ namespace log4cxx
 
 
         LOG4CXX_PTR_DEF(AppenderAttachable);
-        
+
     }
 }
 

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/spi/errorhandler.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/spi/errorhandler.h b/src/main/include/log4cxx/spi/errorhandler.h
index 5bb363e..11faa90 100644
--- a/src/main/include/log4cxx/spi/errorhandler.h
+++ b/src/main/include/log4cxx/spi/errorhandler.h
@@ -69,7 +69,7 @@ namespace log4cxx
                                 LOG4CXX_CAST_ENTRY(ErrorHandler)
                                 LOG4CXX_CAST_ENTRY(OptionHandler)
                         END_LOG4CXX_CAST_MAP()
-                       
+
                         virtual ~ErrorHandler() {}
 
                                 /**

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/spi/filter.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/spi/filter.h b/src/main/include/log4cxx/spi/filter.h
index 83c5dc7..80ce59b 100644
--- a/src/main/include/log4cxx/spi/filter.h
+++ b/src/main/include/log4cxx/spi/filter.h
@@ -87,7 +87,7 @@ namespace log4cxx
 
                         log4cxx::spi::FilterPtr getNext() const;
                         void setNext(const log4cxx::spi::FilterPtr& newNext);
- 
+
             enum FilterDecision
             {
             /**

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/spi/hierarchyeventlistener.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/spi/hierarchyeventlistener.h b/src/main/include/log4cxx/spi/hierarchyeventlistener.h
index 7112397..98e8f86 100644
--- a/src/main/include/log4cxx/spi/hierarchyeventlistener.h
+++ b/src/main/include/log4cxx/spi/hierarchyeventlistener.h
@@ -45,11 +45,11 @@ namespace log4cxx
                         virtual ~HierarchyEventListener() {}
 
                         virtual void addAppenderEvent(
-                     const log4cxx::helpers::ObjectPtrT<Logger>& logger, 
+                     const log4cxx::helpers::ObjectPtrT<Logger>& logger,
                      const log4cxx::helpers::ObjectPtrT<Appender>& appender) = 0;
 
                         virtual void removeAppenderEvent(
-                     const log4cxx::helpers::ObjectPtrT<Logger>& logger, 
+                     const log4cxx::helpers::ObjectPtrT<Logger>& logger,
                      const log4cxx::helpers::ObjectPtrT<Appender>& appender) = 0;
                 };
                 LOG4CXX_PTR_DEF(HierarchyEventListener);

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/spi/loggerfactory.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/spi/loggerfactory.h b/src/main/include/log4cxx/spi/loggerfactory.h
index 07f8be9..ff9be2f 100644
--- a/src/main/include/log4cxx/spi/loggerfactory.h
+++ b/src/main/include/log4cxx/spi/loggerfactory.h
@@ -35,7 +35,7 @@ namespace log4cxx
                         DECLARE_ABSTRACT_LOG4CXX_OBJECT(LoggerFactory)
                         virtual ~LoggerFactory() {}
                         virtual LoggerPtr makeNewLoggerInstance(
-                            log4cxx::helpers::Pool& pool, 
+                            log4cxx::helpers::Pool& pool,
                             const LogString& name) const = 0;
                 };
 

http://git-wip-us.apache.org/repos/asf/logging-log4cxx/blob/fb126e74/src/main/include/log4cxx/spi/loggerrepository.h
----------------------------------------------------------------------
diff --git a/src/main/include/log4cxx/spi/loggerrepository.h b/src/main/include/log4cxx/spi/loggerrepository.h
index 4fe7957..1949d17 100644
--- a/src/main/include/log4cxx/spi/loggerrepository.h
+++ b/src/main/include/log4cxx/spi/loggerrepository.h
@@ -33,7 +33,7 @@ namespace log4cxx
 {
     namespace spi
         {
-            
+
             /**
             A <code>LoggerRepository</code> is used to create and retrieve
             <code>Loggers</code>. The relation between loggers in a repository