You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@openoffice.apache.org by ms...@apache.org on 2023/10/30 01:47:24 UTC

(openoffice) branch trunk updated: Fixed typo (conenction -> connection) and some other

This is an automated email from the ASF dual-hosted git repository.

mseidel pushed a commit to branch trunk
in repository https://gitbox.apache.org/repos/asf/openoffice.git


The following commit(s) were added to refs/heads/trunk by this push:
     new 5589416a0e Fixed typo (conenction -> connection) and some other
5589416a0e is described below

commit 5589416a0ec17d91f1449733cbb3b602760daacc
Author: mseidel <ms...@apache.org>
AuthorDate: Mon Oct 30 02:46:45 2023 +0100

    Fixed typo (conenction -> connection) and some other
---
 main/connectivity/source/cpool/ZConnectionPool.cxx | 30 +++++----
 main/dbaccess/source/ui/browser/unodatbr.cxx       | 42 ++++++------
 main/dbaccess/source/ui/inc/RelationControl.hxx    | 33 +++++-----
 .../source/ui/querydesign/QueryTableView.cxx       | 76 +++++++++++-----------
 main/vos/docu/.html                                |  2 +-
 main/vos/inc/vos/socket.hxx                        | 29 +++++----
 .../com/sun/star/wizards/web/FTPDialog.java        | 41 ++++++------
 7 files changed, 131 insertions(+), 122 deletions(-)

diff --git a/main/connectivity/source/cpool/ZConnectionPool.cxx b/main/connectivity/source/cpool/ZConnectionPool.cxx
index 5e4045a2de..3ce8256694 100644
--- a/main/connectivity/source/cpool/ZConnectionPool.cxx
+++ b/main/connectivity/source/cpool/ZConnectionPool.cxx
@@ -1,5 +1,5 @@
 /**************************************************************
- * 
+ *
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -7,16 +7,16 @@
  * 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.
- * 
+ *
  *************************************************************/
 
 
@@ -67,7 +67,7 @@ namespace
 		static ::rtl::OUString s_sNodeName = ::rtl::OUString::createFromAscii("Timeout");
 		return s_sNodeName;
 	}
-	
+
 }
 //==========================================================================
 //= OConnectionPool
@@ -93,7 +93,7 @@ OConnectionPool::OConnectionPool(const Reference< XDriver >& _xDriver,
 
 	OPoolCollection::getNodeValue(getTimeoutNodeName(),m_xDriverNode) >>= m_nALiveCount;
 	calculateTimeOuts();
-	
+
 	m_xInvalidator = new OPoolTimer(this,::vos::TTimeValue(m_nTimeOut,0));
 	m_xInvalidator->start();
 }
@@ -109,7 +109,7 @@ struct TRemoveEventListenerFunctor : ::std::unary_function<TPooledConnections::v
 	OConnectionPool* m_pConnectionPool;
 	sal_Bool m_bDispose;
 
-	TRemoveEventListenerFunctor(OConnectionPool* _pConnectionPool,sal_Bool _bDispose = sal_False) 
+	TRemoveEventListenerFunctor(OConnectionPool* _pConnectionPool,sal_Bool _bDispose = sal_False)
 		: m_pConnectionPool(_pConnectionPool)
 		,m_bDispose(_bDispose)
 	{
@@ -143,7 +143,7 @@ struct TConnectionPoolFunctor : ::std::unary_function<TConnectionMap::value_type
 {
 	OConnectionPool* m_pConnectionPool;
 
-	TConnectionPoolFunctor(OConnectionPool* _pConnectionPool) 
+	TConnectionPoolFunctor(OConnectionPool* _pConnectionPool)
 		: m_pConnectionPool(_pConnectionPool)
 	{
 		OSL_ENSURE(m_pConnectionPool,"No connection pool!");
@@ -195,7 +195,7 @@ Reference< XConnection > SAL_CALL OConnectionPool::getConnectionWithInfo( const
 
 	if ( !xConnection.is() )
 		xConnection = createNewConnection(_rURL,_rInfo);
-	
+
 	return xConnection;
 }
 //--------------------------------------------------------------------------
@@ -206,7 +206,7 @@ void SAL_CALL OConnectionPool::disposing( const ::com::sun::star::lang::EventObj
 	{
 		MutexGuard aGuard(m_aMutex);
 		TActiveConnectionMap::iterator aIter = m_aActiveConnections.find(xConnection);
-		OSL_ENSURE(aIter != m_aActiveConnections.end(),"OConnectionPool::disposing: Conenction wasn't in pool");
+		OSL_ENSURE(aIter != m_aActiveConnections.end(),"OConnectionPool::disposing: Connection wasn't in pool");
 		if(aIter != m_aActiveConnections.end())
 		{ // move the pooled connection back to the pool
 			aIter->second.aPos->second.nALiveCount = m_nALiveCount;
@@ -222,7 +222,7 @@ void SAL_CALL OConnectionPool::disposing( const ::com::sun::star::lang::EventObj
 // -----------------------------------------------------------------------------
 Reference< XConnection> OConnectionPool::createNewConnection(const ::rtl::OUString& _rURL,const Sequence< PropertyValue >& _rInfo)
 {
-	// create new pooled conenction
+	// create new pooled connection
 	Reference< XPooledConnection > xPooledConnection = new ::connectivity::OPooledConnection(m_xDriver->connect(_rURL,_rInfo),m_xProxyFactory);
 	// get the new connection from the pooled connection
 	Reference<XConnection> xConnection = xPooledConnection->getConnection();
@@ -238,7 +238,7 @@ Reference< XConnection> OConnectionPool::createNewConnection(const ::rtl::OUStri
 		TConnectionMap::key_type nId;
 		OConnectionWrapper::createUniqueId(_rURL,aInfo,nId.m_pBuffer);
 		TConnectionPool aPack;
-		
+
 		// insert the new connection and struct into the active connection map
 		aPack.nALiveCount				= m_nALiveCount;
 		TActiveConnectionInfo aActiveInfo;
@@ -259,7 +259,7 @@ void OConnectionPool::invalidatePooledConnections()
 	TConnectionMap::iterator aIter = m_aPool.begin();
 	for (; aIter != m_aPool.end(); )
 	{
-		if(!(--(aIter->second.nALiveCount))) // connections are invalid 
+		if(!(--(aIter->second.nALiveCount))) // connections are invalid
 		{
 			::std::for_each(aIter->second.aConnections.begin(),aIter->second.aConnections.end(),TRemoveEventListenerFunctor(this,sal_True));
 
@@ -302,7 +302,7 @@ Reference< XConnection> OConnectionPool::getPooledConnection(TConnectionMap::ite
 		Reference< XComponent >  xComponent(xConnection, UNO_QUERY);
 		if (xComponent.is())
 			xComponent->addEventListener(this);
-		
+
 		TActiveConnectionInfo aActiveInfo;
 		aActiveInfo.aPos = _rIter;
 		aActiveInfo.xPooledConnection = xPooledConnection;
@@ -330,3 +330,5 @@ void OConnectionPool::calculateTimeOuts()
 	m_nALiveCount	= m_nALiveCount / m_nTimeOut;
 }
 // -----------------------------------------------------------------------------
+
+/* vim: set noet sw=4 ts=4: */
diff --git a/main/dbaccess/source/ui/browser/unodatbr.cxx b/main/dbaccess/source/ui/browser/unodatbr.cxx
index da364e8399..352a1be299 100644
--- a/main/dbaccess/source/ui/browser/unodatbr.cxx
+++ b/main/dbaccess/source/ui/browser/unodatbr.cxx
@@ -1,5 +1,5 @@
 /**************************************************************
- * 
+ *
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -7,16 +7,16 @@
  * 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.
- * 
+ *
  *************************************************************/
 
 
@@ -313,10 +313,10 @@ Sequence< sal_Int8 > SAL_CALL SbaTableQueryBrowser::getImplementationId(  ) thro
 void SAL_CALL SbaTableQueryBrowser::disposing()
 {
 	::vos::OGuard aGuard(Application::GetSolarMutex());
-		// doin' a lot of VCL stuff here -> lock the SolarMutex
+		// doing a lot of VCL stuff here -> lock the SolarMutex
 
 	// kiss our listeners goodbye
-	
+
 	::com::sun::star::lang::EventObject aEvt(*this);
 	m_aSelectionListeners.disposeAndClear(aEvt);
     m_aContextMenuInterceptors.disposeAndClear(aEvt);
@@ -519,9 +519,9 @@ void SbaTableQueryBrowser::impl_sanitizeRowSetClauses_nothrow()
         // That'd be a chance to replace getStructuredFilter with something more reasonable. This method
         // has at least one other problem: For a clause like "<column> != <value>", it will return "<column>"
         // as column name, "NOT_EQUAL" as operator, and "!= <value>" as value, effectively duplicating the
-        // information about the operator, and beding all clients to manually remove the "!=" from the value
+        // information about the operator, and begging all clients to manually remove the "!=" from the value
         // string.
-        // So, what really would be handy, is some 
+        // So, what really would be handy, is some
         //   XNormalizedFilter getNormalizedFilter();
         // with
         //   interface XDisjunctiveFilterExpression
@@ -821,7 +821,7 @@ sal_Bool SbaTableQueryBrowser::InitializeGridModel(const Reference< ::com::sun::
                 aDescription >>= sTemp;
                 if ( !sTemp.getLength() )
                     xColumn->getPropertyValue( PROPERTY_DESCRIPTION ) >>= sTemp;
-                
+
                 aDescription <<= sTemp;
                 aInitialValues.push_back( NamedValue( PROPERTY_HELPTEXT, aDescription ) );
 
@@ -1427,7 +1427,7 @@ void SAL_CALL SbaTableQueryBrowser::disposing( const ::com::sun::star::lang::Eve
 				// maybe update the UI
 				implCheckExternalSlot( nSlotId );
 
-				// continue, the same XDispatch may be resposible for more than one URL
+				// continue, the same XDispatch may be responsible for more than one URL
 				aLoop = aNext;
 			}
 		}
@@ -1444,7 +1444,7 @@ void SAL_CALL SbaTableQueryBrowser::disposing( const ::com::sun::star::lang::Eve
 					DBTreeListUserData* pData = static_cast<DBTreeListUserData*>(pDSLoop->GetUserData());
 					if ( pData && pData->xConnection == xCon )
 					{
-						// we set the conenction to null to avoid a second disposing of the connection
+						// we set the connection to null to avoid a second disposing of the connection
 						pData->xConnection.clear();
 						closeConnection(pDSLoop,sal_False);
 						break;
@@ -1487,7 +1487,7 @@ void SbaTableQueryBrowser::implRemoveStatusListeners()
 sal_Bool SAL_CALL SbaTableQueryBrowser::select( const Any& _rSelection ) throw (IllegalArgumentException, RuntimeException)
 {
 	::vos::OGuard aGuard(Application::GetSolarMutex());
-		// doin' a lot of VCL stuff here -> lock the SolarMutex
+		// doing a lot of VCL stuff here -> lock the SolarMutex
 
 	Sequence< PropertyValue > aDescriptorSequence;
 	if (!(_rSelection >>= aDescriptorSequence))
@@ -1504,7 +1504,7 @@ sal_Bool SAL_CALL SbaTableQueryBrowser::select( const Any& _rSelection ) throw (
 		OSL_ENSURE(sal_False, "SbaTableQueryBrowser::select: could not extract the descriptor!");
 	}
 
-	// check the precense of the props we need
+	// check the presence of the props we need
 	if ( !(aDescriptor.has(daDataSource) || aDescriptor.has(daDatabaseLocation)) || !aDescriptor.has(daCommand) || !aDescriptor.has(daCommandType))
 		throw IllegalArgumentException(::rtl::OUString(), *this, 1);
 		// TODO: error message
@@ -2263,7 +2263,7 @@ IMPL_LINK(SbaTableQueryBrowser, OnExpandEntry, SvLBoxEntry*, _pParent)
 
 				// first insert the views because the tables can also include
 				// views but that time the bitmap is the wrong one
-				// the nameaccess will be overwriten in populateTree
+				// the nameaccess will be overwritten in populateTree
 				Reference<XViewsSupplier> xViewSup(xConnection,UNO_QUERY);
 				if(xViewSup.is())
 					populateTree( xViewSup->getViews(), _pParent, etTableOrView );
@@ -2373,7 +2373,7 @@ sal_Bool SbaTableQueryBrowser::ensureEntryObject( SvLBoxEntry* _pEntry )
                     {
                         DBG_UNHANDLED_EXCEPTION();
                     }
-                    
+
                     bSuccess = pEntryData->xContainer.is();
                 }
                 else
@@ -2611,7 +2611,7 @@ bool SbaTableQueryBrowser::implSelect( SvLBoxEntry* _pEntry )
 	sal_Int32 nOldType = 0;
 	xRowSetProps->getPropertyValue(PROPERTY_COMMAND_TYPE) >>= nOldType;
 	Reference<XConnection> xOldConnection(xRowSetProps->getPropertyValue(PROPERTY_ACTIVE_CONNECTION),UNO_QUERY);
-	
+
 	// the name of the table or query
 	SvLBoxString* pString = (SvLBoxString*)_pEntry->GetFirstItem(SV_ITEM_ID_BOLDLBSTRING);
 	OSL_ENSURE(pString,"There must be a string item!");
@@ -3155,7 +3155,7 @@ namespace
 void SbaTableQueryBrowser::impl_initialize()
 {
 	::vos::OGuard aGuard(Application::GetSolarMutex());
-		// doin' a lot of VCL stuff here -> lock the SolarMutex
+		// doing a lot of VCL stuff here -> lock the SolarMutex
 
 	// first initialize the parent
 	SbaXDataBrowserController::impl_initialize();
@@ -3452,7 +3452,7 @@ IMPL_LINK( SbaTableQueryBrowser, OnTreeEntryCompare, const SvSortData*, _pSortDa
 
 	if (isContainer(pRHS))
 	{
-		// don't use getEntryType (directly or indirecly) for the LHS:
+		// don't use getEntryType (directly or indirectly) for the LHS:
 		// LHS is currently being inserted, so it is not "completely valid" at the moment
 
 		const EntryType eRight = getEntryType(pRHS);
@@ -3501,7 +3501,7 @@ IMPL_LINK( SbaTableQueryBrowser, OnTreeEntryCompare, const SvSortData*, _pSortDa
 		}
 	}
 	else
-		// default behaviour if we do not have a collator -> do the simple string compare
+		// default behavior if we do not have a collator -> do the simple string compare
 		nCompareResult = sLeftText.CompareTo(sRightText);
 
 	return nCompareResult;
@@ -3648,7 +3648,7 @@ sal_Bool SbaTableQueryBrowser::implGetQuerySignature( ::rtl::OUString& _rCommand
 
 	try
 	{
-		// ontain the dss (data source signature) of the form
+		// contain the dss (data source signature) of the form
 		::rtl::OUString sDataSourceName;
 		::rtl::OUString sCommand;
 		sal_Int32		nCommandType = CommandType::COMMAND;
@@ -3930,4 +3930,4 @@ void SAL_CALL SbaTableQueryBrowser::changedDatabaseLocation( const DatabaseRegis
 }	// namespace dbaui
 // .........................................................................
 
-
+/* vim: set noet sw=4 ts=4: */
diff --git a/main/dbaccess/source/ui/inc/RelationControl.hxx b/main/dbaccess/source/ui/inc/RelationControl.hxx
index 013e425a16..e45d0a7508 100644
--- a/main/dbaccess/source/ui/inc/RelationControl.hxx
+++ b/main/dbaccess/source/ui/inc/RelationControl.hxx
@@ -1,5 +1,5 @@
 /**************************************************************
- * 
+ *
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -7,19 +7,20 @@
  * 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 DBAUI_RELATIONCONTROL_HXX
 #define DBAUI_RELATIONCONTROL_HXX
 
@@ -38,8 +39,8 @@ namespace dbaui
 	//========================================================================
 	class OTableListBoxControl;
 	class OTableConnectionData;
-	class ORelationTableConnectionData;	
-	class IRelationControlInterface;	
+	class ORelationTableConnectionData;
+	class IRelationControlInterface;
 	class ORelationControl;
 
 	class OTableListBoxControl	: public Window
@@ -68,28 +69,28 @@ namespace dbaui
 		void fillListBoxes();
 
 		/** fillAndDisable fill the listboxes only with one entry and then disable them
-			@param	_pConnectionData 
+			@param	_pConnectionData
 					contains the data which should be filled into the listboxes
 		*/
 		void fillAndDisable(const TTableConnectionData::value_type& _pConnectionData);
 
-        /** enables the relation control
-        *
-        * \param _bEnable when sal_True enables it, otherwise disable it.
-        */
-        void enableRelation(bool _bEnable);
+		/** enables the relation control
+		*
+		* \param _bEnable when sal_True enables it, otherwise disable it.
+		*/
+		void enableRelation(bool _bEnable);
 
-		/** NotifyCellChange notifies the browse control that the conenction data has changed
+		/** NotifyCellChange notifies the browse control that the connection data has changed
 		*/
 		void NotifyCellChange();
 
 		/** Init is a call through to the control inside this one
-			@param	_pConnData	
+			@param	_pConnData
 					the connection data which is used to init the control
 		*/
 		void Init(const TTableConnectionData::value_type& _pConnData);
 		void lateUIInit(Window* _pTableSeparator = NULL);
-        void lateInit();
+		void lateInit();
 
 		sal_Bool SaveModified();
 
@@ -102,3 +103,5 @@ namespace dbaui
 	};
 }
 #endif // DBAUI_RELATIONCONTROL_HXX
+
+/* vim: set noet sw=4 ts=4: */
diff --git a/main/dbaccess/source/ui/querydesign/QueryTableView.cxx b/main/dbaccess/source/ui/querydesign/QueryTableView.cxx
index 88c8fa8e19..415769d86f 100644
--- a/main/dbaccess/source/ui/querydesign/QueryTableView.cxx
+++ b/main/dbaccess/source/ui/querydesign/QueryTableView.cxx
@@ -1,5 +1,5 @@
 /**************************************************************
- * 
+ *
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -7,16 +7,16 @@
  * 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.
- * 
+ *
  *************************************************************/
 
 
@@ -128,7 +128,7 @@ using namespace ::com::sun::star::container;
 using namespace ::com::sun::star::accessibility;
 
 //------------------------------------------------------------------------------
-namespace 
+namespace
 {
 	// -----------------------------------------------------------------------------
 	sal_Bool isColumnInKeyType(const Reference<XIndexAccess>& _rxKeys,const ::rtl::OUString& _rColumnName,sal_Int32 _nKeyType)
@@ -138,7 +138,7 @@ namespace
 		{
 			Reference<XColumnsSupplier> xColumnsSupplier;
 			// search the one and only primary key
-            const sal_Int32 nCount = _rxKeys->getCount();
+			const sal_Int32 nCount = _rxKeys->getCount();
 			for(sal_Int32 i=0;i< nCount;++i)
 			{
 				Reference<XPropertySet> xProp(_rxKeys->getByIndex(i),UNO_QUERY);
@@ -188,7 +188,7 @@ namespace
 
 		@return	true when OK was pressed otherwise false
 	*/
-    sal_Bool openJoinDialog(OQueryTableView* _pView,const TTableConnectionData::value_type& _pConnectionData,sal_Bool _bSelectableTables)
+	sal_Bool openJoinDialog(OQueryTableView* _pView,const TTableConnectionData::value_type& _pConnectionData,sal_Bool _bSelectableTables)
 	{
 		OQueryTableConnectionData* pData = static_cast< OQueryTableConnectionData*>(_pConnectionData.get());
 
@@ -237,7 +237,7 @@ namespace
             // nothing to do if one of both denotes a query
             return;
 
-		// we found a table in our view where we can insert some connections 
+		// we found a table in our view where we can insert some connections
 		// the key columns have a property called RelatedColumn
 		// OQueryTableConnectionData aufbauen
         OQueryTableConnectionData* pNewConnData = new OQueryTableConnectionData( _rSource.GetData(), _rDest.GetData() );
@@ -271,7 +271,7 @@ namespace
 				else
 					OSL_ENSURE(0,"Column not found!");
 			}
-			// get the position inside the tabe 
+			// get the position inside the table
 			Reference<XNameAccess> xRefColumns = _rDest.GetOriginalColumns();
 			if(xRefColumns.is())
 			{
@@ -350,7 +350,7 @@ void OQueryTableView::ReSync()
 
 	TTableWindowData::reverse_iterator aIter = pTabWinDataList->rbegin();
 	// Fenster kreieren und einfuegen
-	
+
 	for(;aIter != pTabWinDataList->rend();++aIter)
 	{
 		OQueryTableWindowData* pData = static_cast<OQueryTableWindowData*>(aIter->get());
@@ -382,7 +382,7 @@ void OQueryTableView::ReSync()
 	// Verbindungen einfuegen
 	TTableConnectionData* pTabConnDataList = m_pView->getController().getTableConnectionData();
 	TTableConnectionData::reverse_iterator aConIter = pTabConnDataList->rbegin();
-	
+
 	for(;aConIter != pTabConnDataList->rend();++aConIter)
 	{
 		OQueryTableConnectionData* pTabConnData =  static_cast<OQueryTableConnectionData*>(aConIter->get());
@@ -399,7 +399,7 @@ void OQueryTableView::ReSync()
 			continue;
 		}
 
-		// adds a new connection to join view and notifies our accessible and invaldates the controller
+		// adds a new connection to join view and notifies our accessible and invalidates the controller
 		addConnection(new OQueryTableConnection(this, *aConIter));
 	}
 }
@@ -427,7 +427,7 @@ void OQueryTableView::NotifyTabConnection(const OQueryTableConnection& rNewConn,
 	// erst mal schauen, ob ich diese Connection schon habe
 	OQueryTableConnection* pTabConn = NULL;
 	const ::std::vector<OTableConnection*>*	pConnections = getTableConnections();
-    ::std::vector<OTableConnection*>::const_iterator aEnd = pConnections->end();
+	::std::vector<OTableConnection*>::const_iterator aEnd = pConnections->end();
 	::std::vector<OTableConnection*>::const_iterator aIter = ::std::find(	pConnections->begin(),
 													aEnd,
 													static_cast<const OTableConnection*>(&rNewConn)
@@ -452,7 +452,7 @@ void OQueryTableView::NotifyTabConnection(const OQueryTableConnection& rNewConn,
 		// die neuen Daten ...
 		OQueryTableConnectionData* pNewData = static_cast< OQueryTableConnectionData*>(rNewConn.GetData()->NewInstance());
 		pNewData->CopyFrom(*rNewConn.GetData());
-        TTableConnectionData::value_type aData(pNewData);
+		TTableConnectionData::value_type aData(pNewData);
 		OQueryTableConnection* pNewConn = new OQueryTableConnection(this, aData);
 		GetConnection(pNewConn);
 
@@ -484,8 +484,8 @@ void OQueryTableView::AddTabWin(const ::rtl::OUString& _rTableName, const ::rtl:
 		::rtl::OUString sCatalog, sSchema, sTable;
 		::dbtools::qualifiedNameComponents(xMetaData,
 									_rTableName,
-									sCatalog, 
-									sSchema, 
+									sCatalog,
+									sSchema,
 									sTable,
 									::dbtools::eInDataManipulation);
 		::rtl::OUString sRealName(sSchema);
@@ -501,7 +501,7 @@ void OQueryTableView::AddTabWin(const ::rtl::OUString& _rTableName, const ::rtl:
 	}
 }
 // -----------------------------------------------------------------------------
-// find the table which has a foreign key with this referencedTable name 
+// find the table which has a foreign key with this referencedTable name
 Reference<XPropertySet> getKeyReferencedTo(const Reference<XIndexAccess>& _rxKeys,const ::rtl::OUString& _rReferencedTable)
 {
 	if(!_rxKeys.is())
@@ -510,7 +510,7 @@ Reference<XPropertySet> getKeyReferencedTo(const Reference<XIndexAccess>& _rxKey
 	if ( !_rxKeys.is() )
 		return Reference<XPropertySet>();
 	// search the one and only primary key
-    const sal_Int32 nCount = _rxKeys->getCount();
+	const sal_Int32 nCount = _rxKeys->getCount();
 	for(sal_Int32 i=0;i<nCount ;++i)
 	{
 		Reference<XPropertySet> xKey(_rxKeys->getByIndex(i),UNO_QUERY);
@@ -538,20 +538,20 @@ void OQueryTableView::AddTabWin(const ::rtl::OUString& _rComposedName, const ::r
 		// wenn der Tabellenname nicht gesetzt ist, steht das fuer ein Dummy-Fenster, das braucht aber wenigstens einen Alias-Namen
 
 	// neue Datenstruktur erzeugen
-	// first check if this already hav it's data
+	// first check if this already have its data
 	sal_Bool bAppend = bNewTable;
 	TTableWindowData::value_type pNewTabWinData;
 	TTableWindowData* pWindowData = getDesignView()->getController().getTableWindowData();
 	TTableWindowData::iterator aWinIter = pWindowData->begin();
-    TTableWindowData::iterator aWinEnd = pWindowData->end();
+	TTableWindowData::iterator aWinEnd = pWindowData->end();
 	for(;aWinIter != aWinEnd;++aWinIter)
 	{
 		pNewTabWinData = *aWinIter;
 		if (pNewTabWinData && pNewTabWinData->GetWinName() == strAlias && pNewTabWinData->GetComposedName() == _rComposedName && pNewTabWinData->GetTableName() == _rTableName)
 			break;
 	}
-    if ( !bAppend )
-        bAppend = ( aWinIter == aWinEnd );
+	if ( !bAppend )
+		bAppend = ( aWinIter == aWinEnd );
 	if ( bAppend )
 		pNewTabWinData = createTableWindowData(_rComposedName, _rTableName, strAlias);
 		// die TabWinData brauche ich nicht in die entsprechende Liste der DocShell eintragen, das macht ShowTabWin
@@ -567,7 +567,7 @@ void OQueryTableView::AddTabWin(const ::rtl::OUString& _rComposedName, const ::r
 	if(!bSuccess)
 	{
 		// reset table window
-		pUndoAction->SetTabWin(NULL); 
+		pUndoAction->SetTabWin(NULL);
 		pUndoAction->SetOwnership(sal_False);
 
 		delete pUndoAction;
@@ -757,7 +757,7 @@ void OQueryTableView::ConnDoubleClicked(OTableConnection* pConnection)
 // -----------------------------------------------------------------------------
 void OQueryTableView::createNewConnection()
 {
-    TTableConnectionData::value_type pData(new OQueryTableConnectionData());
+	TTableConnectionData::value_type pData(new OQueryTableConnectionData());
 	if( openJoinDialog(this,pData,sal_True) )
 	{
 		OTableWindowMap* pMap = GetTabWinMap();
@@ -773,7 +773,7 @@ void OQueryTableView::createNewConnection()
 		}
 		else
 		{
-			// create a new conenction and append it
+			// create a new connection and append it
 			OQueryTableConnection* pQConn = new OQueryTableConnection(this, pData);
 			GetConnection(pQConn);
 			pConn = pQConn;
@@ -824,7 +824,7 @@ sal_Bool OQueryTableView::FindTableFromField(const String& rFieldName, OTableFie
 	DBG_CHKTHIS(OQueryTableView,NULL);
 	rCnt = 0;
 	OTableWindowMap::const_iterator aIter = GetTabWinMap()->begin();
-    OTableWindowMap::const_iterator aEnd  = GetTabWinMap()->end();
+	OTableWindowMap::const_iterator aEnd  = GetTabWinMap()->end();
 	for(;aIter != aEnd;++aIter)
 	{
 		if(static_cast<OQueryTableWindow*>(aIter->second)->ExistsField(rFieldName, rInfo))
@@ -891,16 +891,16 @@ void OQueryTableView::RemoveTabWin(OTableWindow* pTabWin)
 	    if ( m_pAccessible )
 		    m_pAccessible->notifyAccessibleEvent(	AccessibleEventId::CHILD,
 												    makeAny(pTabWin->GetAccessible()),
-												    Any()												
+												    Any()
 												    );
-    }
+	}
 }
 
 //------------------------------------------------------------------------
 void OQueryTableView::EnsureVisible(const OTableWindow* pWin)
 {
 	DBG_CHKTHIS(OQueryTableView,NULL);
-	
+
 	Invalidate(INVALIDATE_NOCHILDREN);
 	OJoinTableView::EnsureVisible(pWin);
 }
@@ -910,7 +910,7 @@ void OQueryTableView::GetConnection(OQueryTableConnection* pConn)
 {
 	DBG_CHKTHIS(OQueryTableView,NULL);
 	// bei mir und dem Dokument einfuegen
-	
+
 	addConnection( pConn );
 	// invalidieren (damit es neu gezeichnet wird)
 	//	pConn->Invalidate();
@@ -1038,7 +1038,7 @@ sal_Bool OQueryTableView::ShowTabWin( OQueryTableWindow* pTabWin, OQueryTabWinUn
 			// die Connections
 			::std::vector<OTableConnection*>* pTableCon = pUndoAction->GetTabConnList();
 			::std::vector<OTableConnection*>::iterator aIter = pTableCon->begin();
-            ::std::vector<OTableConnection*>::iterator aEnd = pTableCon->end();
+			::std::vector<OTableConnection*>::iterator aEnd = pTableCon->end();
 
 			for(;aIter != aEnd;++aIter)
 				addConnection(*aIter); // add all connections from the undo action
@@ -1072,7 +1072,7 @@ sal_Bool OQueryTableView::ShowTabWin( OQueryTableWindow* pTabWin, OQueryTabWinUn
 	// damit habe ich das Doc natuerlich modifiziert
 	if(!m_pView->getController().isReadOnly())
 		m_pView->getController().setModified( sal_True );
-	
+
 	m_pView->getController().InvalidateFeature(SID_BROWSER_CLEAR_QUERY);
 
 	return bSuccess;
@@ -1092,7 +1092,7 @@ sal_Bool OQueryTableView::ExistsAVisitedConn(const OQueryTableWindow* pFrom) con
 	if (pList)
 	{
 		::std::vector<OTableConnection*>::const_iterator aIter = pList->begin();
-        ::std::vector<OTableConnection*>::const_iterator aEnd = pList->end();
+		::std::vector<OTableConnection*>::const_iterator aEnd = pList->end();
 		for(;aIter != aEnd;++aIter)
 		{
 			OQueryTableConnection* pTemp = static_cast<OQueryTableConnection*>(*aIter);
@@ -1107,13 +1107,15 @@ sal_Bool OQueryTableView::ExistsAVisitedConn(const OQueryTableWindow* pFrom) con
 // -----------------------------------------------------------------------------
 void OQueryTableView::onNoColumns_throw()
 {
-    String sError( ModuleRes( STR_STATEMENT_WITHOUT_RESULT_SET ) );
-    ::dbtools::throwSQLException( sError, ::dbtools::SQL_GENERAL_ERROR, NULL );
+	String sError( ModuleRes( STR_STATEMENT_WITHOUT_RESULT_SET ) );
+	::dbtools::throwSQLException( sError, ::dbtools::SQL_GENERAL_ERROR, NULL );
 }
 //------------------------------------------------------------------------------
 bool OQueryTableView::supressCrossNaturalJoin(const TTableConnectionData::value_type& _pData) const
 {
-    OQueryTableConnectionData* pQueryData = static_cast<OQueryTableConnectionData*>(_pData.get());
-    return pQueryData && (pQueryData->GetJoinType() == CROSS_JOIN);
+	OQueryTableConnectionData* pQueryData = static_cast<OQueryTableConnectionData*>(_pData.get());
+	return pQueryData && (pQueryData->GetJoinType() == CROSS_JOIN);
 }
 // -----------------------------------------------------------------------------
+
+/* vim: set noet sw=4 ts=4: */
diff --git a/main/vos/docu/.html b/main/vos/docu/.html
index 1c1afda5f0..d274880a78 100644
--- a/main/vos/docu/.html
+++ b/main/vos/docu/.html
@@ -140,7 +140,7 @@ A thread used to execute an IExecutable-Object</I>
 </TD></TR><TR><TD VALIGN=top><IMG BORDER=0 SRC=icon1.gif> </TD><TD><A HREF=OAcceptorSocket.html><B>OAcceptorSocket</B></A> <br>
 <I>A socket to accept incoming connections</I>
 </TD></TR><TR><TD VALIGN=top><IMG BORDER=0 SRC=icon1.gif> </TD><TD><A HREF=OConnectorSocket.html><B>OConnectorSocket</B></A> <br>
-<I>A socket to initiate a conenction</I>
+<I>A socket to initiate a connection</I>
 </TD></TR><TR><TD VALIGN=top><IMG BORDER=0 SRC=icon1.gif> </TD><TD><A HREF=ODatagramSocket.html><B>ODatagramSocket</B></A> <br>
 <I>A connectionless socket to send and receive datagrams</I>
 </TD></TR><TR><TD VALIGN=top><IMG BORDER=0 SRC=icon1.gif> </TD><TD><A HREF=IPositionableStream.html><B>IPositionableStream</B></A> <br>
diff --git a/main/vos/inc/vos/socket.hxx b/main/vos/inc/vos/socket.hxx
index 1966a516b4..f8643c4d5e 100644
--- a/main/vos/inc/vos/socket.hxx
+++ b/main/vos/inc/vos/socket.hxx
@@ -1,5 +1,5 @@
 /**************************************************************
- * 
+ *
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -7,16 +7,16 @@
  * 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.
- * 
+ *
  *************************************************************/
 
 
@@ -288,7 +288,7 @@ public:
 
     /**
         Create a socket address either from a dotted decimal address
-        (e.g. 141.99.128.50) or a hostname (e.g. www.stardiv.de).
+        (e.g. 141.99.128.50) or a hostname (e.g. www.openoffice.org).
     */
     OInetSocketAddr(const ::rtl::OUString& strAddrOrHostName, sal_Int32 Port);
 
@@ -444,7 +444,7 @@ protected:
 public:
 
     /** Does not create a socket. Use assignment operator to
-        make this a useable socket.
+        make this a usable socket.
     */
     OSocket();
 
@@ -570,7 +570,7 @@ public:
         will NOT block; False if it would block or if an error occurred.
 
         @param pTimeout if 0, the operation will block without a timeout. Otherwise
-        the specified amout of time.
+        the specified amount of time.
     */
     sal_Bool    SAL_CALL isRecvReady(const TimeValue* pTimeout = 0) const;
 
@@ -581,7 +581,7 @@ public:
         will NOT block; False if it would block or if an error occurred.
 
         @param pTimeout if 0, the operation will block without a timeout. Otherwise
-        the specified amout of time.
+        the specified amount of time.
     */
     sal_Bool    SAL_CALL isSendReady(const TimeValue* pTimeout = 0) const;
 
@@ -593,7 +593,7 @@ public:
         on the Socket will NOT block; False if it would block or if an error occurred.
 
         @param pTimeout if 0, the operation will block without a timeout. Otherwise
-        the specified amout of time.
+        the specified amount of time.
     */
     sal_Bool    SAL_CALL isExceptionPending(const TimeValue* pTimeout = 0) const;
 
@@ -689,7 +689,7 @@ public:
 
     /** Enables/disables non-blocking mode of the socket.
         @param On If True, non-blocking mode will be switched on, if False
-        socket will become a blocking socket, which is the default behaviour of a
+        socket will become a blocking socket, which is the default behavior of a
         socket.
         @return True if mode could be set.
     */
@@ -796,7 +796,7 @@ public:
     void SAL_CALL getError(::rtl::OUString& strError) const;
 
     /** Delivers a constant describing the last error for the socket system.
-        @return ENONE if no error occurred, invalid_SocketError if
+        @return NONE if no error occurred, invalid_SocketError if
         an unknown (unmapped) error occurred, otherwise an enum describing the
         error.
     */
@@ -1009,7 +1009,7 @@ public:
 };
 
 
-/** A socket to initiate a conenction.
+/** A socket to initiate a connection.
 */
 class VOS_DLLPUBLIC OConnectorSocket : public vos::OStreamSocket
 {
@@ -1071,7 +1071,7 @@ public:
     /** Tries to receives BufferSize data from the socket, if no error occurs.
 
         @param pSenderAddr [out] You must provide pointer to a SocketAddr.
-        It will be  filled with the address of the datagrams sender.
+        It will be filled with the address of the datagrams sender.
         If pSenderAddr is 0, it is ignored.
         @param pBuffer [out] Points to a buffer that will be filled with the received
         datagram.
@@ -1093,7 +1093,7 @@ public:
                      TSocketMsgFlag Flag= TMsg_Normal);
 
     /** Tries to send one datagram with BytesToSend data to the given ReceiverAddr.
-        Since we only send one packet, we don't need to concern ourselfes here with
+        Since we only send one packet, we don't need to concern ourselves here with
         incomplete sends due to packet boundaries.
 
         @param ReceiverAddr [in] A SocketAddr that contains
@@ -1125,3 +1125,4 @@ public:
 
 #endif // _VOS_SOCKET_HXX_
 
+/* vim: set noet sw=4 ts=4: */
diff --git a/main/wizards/com/sun/star/wizards/web/FTPDialog.java b/main/wizards/com/sun/star/wizards/web/FTPDialog.java
index 95550e01f5..d2f85cca9d 100644
--- a/main/wizards/com/sun/star/wizards/web/FTPDialog.java
+++ b/main/wizards/com/sun/star/wizards/web/FTPDialog.java
@@ -1,5 +1,5 @@
 /**************************************************************
- * 
+ *
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -7,19 +7,20 @@
  * 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.
- * 
+ *
  *************************************************************/
 
 
+
 package com.sun.star.wizards.web;
 
 import java.util.List;
@@ -54,13 +55,13 @@ import com.sun.star.wizards.common.HelpIds;
 
 /**
  * This is the FTP Dialog. <br/>
- * The Dialog enables the user: 
+ * The Dialog enables the user:
  * (*) entering FTP server and user information.
  * (*) testing the connection.
  * (*) choosing a directory on the server.
  * If a connection was established successfully, the user may
  * press OK, which will change
- * the CGPublish object propertiers according the user's input.
+ * the CGPublish object properties according the user's input.
  * If no connection was established. the OK and Choose-Dir button are disabled.
  * See the method "disconnect()" which disables them.
  *
@@ -73,7 +74,7 @@ public class FTPDialog extends UnoDialog2 implements UIConsts, WWHID
 
     /**
      * A Constant used for the setLabel(int) method to change the
-     * status-display. "unknown" is the status when the user first 
+     * status-display. "unknown" is the status when the user first
      * opens the dialog, or changes the servername/username/password.
      */
     private final static int STATUS_UNKONWN = 0;
@@ -121,7 +122,7 @@ public class FTPDialog extends UnoDialog2 implements UIConsts, WWHID
      */
     private final static String ICON_UNKNOWN = "ftpunknown.gif";
     /**
-     * The icon url for an icon representing the "connecting" state. 
+     * The icon url for an icon representing the "connecting" state.
      */
     private final static String ICON_CONNECTING = "ftpconnecting.gif";    //GUI Components as Class members.
     //Fixed Line
@@ -174,9 +175,9 @@ public class FTPDialog extends UnoDialog2 implements UIConsts, WWHID
      * constructor.
      * constructs the UI.
      * @param xmsf
-     * @param p the publishert object that contains the data
+     * @param p the publisher object that contains the data
      * for this dialog
-     * @throws Exception 
+     * @throws Exception
      */
     public FTPDialog(XMultiServiceFactory xmsf, CGPublish p) throws Exception
     {
@@ -397,7 +398,7 @@ public class FTPDialog extends UnoDialog2 implements UIConsts, WWHID
     /**
      * updates the hostname, username, password and
      * directory text fields.
-     * is called uppon initialization.
+     * is called upon initialization.
      */
     private void updateUI()
     {
@@ -406,8 +407,8 @@ public class FTPDialog extends UnoDialog2 implements UIConsts, WWHID
     }
 
     /**
-     * extract the hostname out of the url used by the 
-     * publisher. This url does not include the username:password string. 
+     * extract the hostname out of the url used by the
+     * publisher. This url does not include the username:password string.
      * @param ftpUrl
      * @return
      */
@@ -564,7 +565,7 @@ public class FTPDialog extends UnoDialog2 implements UIConsts, WWHID
     }
 
     /**
-     * To try the conenction I do some actions that
+     * To try the connection I do some actions that
      * seem logical to me: <br/>
      * I get a ucb content.
      * I list the files in this content.
@@ -604,7 +605,7 @@ public class FTPDialog extends UnoDialog2 implements UIConsts, WWHID
     }
 
     /**
-     * @return the ftp subdirecrtory.
+     * @return the ftp subdirectory.
      */
     public String getDir()
     {
@@ -614,7 +615,7 @@ public class FTPDialog extends UnoDialog2 implements UIConsts, WWHID
     /**
      * changes the status label to disconnected status, and
      * disables the ok and choose-dir buttons.
-     * This method is called also when the hostname, username 
+     * This method is called also when the hostname, username
      * and passwordtext fields change.
      */
     public void disconnect()
@@ -652,7 +653,7 @@ public class FTPDialog extends UnoDialog2 implements UIConsts, WWHID
     /**
      * changes the status label and icon, according to the
      * given status
-     * @param status one opf the private status-constants.
+     * @param status one of the private status-constants.
      * if this param is not one of them, an "unknown error" status is displayed.
      */
     private void setLabel(int status)
@@ -691,7 +692,7 @@ public class FTPDialog extends UnoDialog2 implements UIConsts, WWHID
     }
 
     /**
-     * changes the text of the status label and 
+     * changes the text of the status label and
      * (TODO) the status image.
      * @param label
      * @param color
@@ -708,7 +709,7 @@ public class FTPDialog extends UnoDialog2 implements UIConsts, WWHID
     }
 
     /**
-     * called when the user clicks 
+     * called when the user clicks
      * the choose-dir button. ("...")
      * Opens the pickFolder dialog.
      * checks if the returned folder is an ftp folder.
@@ -736,7 +737,7 @@ public class FTPDialog extends UnoDialog2 implements UIConsts, WWHID
 
     /**
      * practical to have such a method...
-     * @param p the publisher obejct that contains the ftp connection info.
+     * @param p the publisher object that contains the ftp connection info.
      * @return the full ftp url with username password and everything one needs.
      */
     public static final String getFullURL(CGPublish p)