You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@harmony.apache.org by ay...@apache.org on 2006/12/24 23:29:15 UTC

svn commit: r490076 - in /harmony/enhanced/classlib/trunk/modules/rmi/src: main/java/java/rmi/activation/ main/java/java/rmi/server/ main/java/org/apache/harmony/rmi/ main/java/org/apache/harmony/rmi/activation/ main/java/org/apache/harmony/rmi/client/...

Author: ayza
Date: Sun Dec 24 14:29:13 2006
New Revision: 490076

URL: http://svn.apache.org/viewvc?view=rev&rev=490076
Log:
Applying patch HARMONY-2784 ([Classlib][RMI] Wrong words in rmi module)

Modified:
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/java/rmi/activation/ActivationID.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/java/rmi/server/RMIClassLoader.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/java/rmi/server/RemoteStub.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/java/rmi/server/UnicastRemoteObject.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/DefaultRMIClassLoaderSpi.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/MarshalledObjectInputStream.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/MarshalledObjectOutputStream.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/activation/ActivationGroupImpl.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/activation/Rmid.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/client/ClientConnection.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/client/ClientConnectionManager.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/client/ClientRemoteCall.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/ClassList.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/JavaCompiler.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/RMIHash.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/RMILog.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/RMIUtil.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/compiler/ClassStub.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/compiler/RMICompiler.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/compiler/RmicUtil.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/internal/nls/messages.properties
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/ActivatableRef.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/ActivatableServerRef.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/UnicastRef.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/UnicastRef2.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/UnicastServerRef.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ClientDGC.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/DGCImpl.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ExportManager.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/RMIObjectInfo.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/RMIReference.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/RemoteRefBase.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ServerConnection.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ServerConnectionManager.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ServerRemoteCall.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/DefaultRMISocketFactory.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/Endpoint.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/RMIObjectInputStream.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/RMIObjectOutputStream.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/proxy/HttpConnection.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/proxy/HttpServerConnection.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/proxy/Proxy.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/tcp/TcpConnection.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/tcp/TcpServerConnection.java
    harmony/enhanced/classlib/trunk/modules/rmi/src/test/api/java/org/apache/harmony/rmi/MarshalledObjectTest.java

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/java/rmi/activation/ActivationID.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/java/rmi/activation/ActivationID.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/java/rmi/activation/ActivationID.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/java/rmi/activation/ActivationID.java Sun Dec 24 14:29:13 2006
@@ -68,10 +68,10 @@
             rlog.log(RMILog.VERBOSE, Messages.getString("rmi.log.03")); //$NON-NLS-1$
             return deserialized_stub;
         } catch (IOException ioe) {
-            // rmi.0E=An IOException occured while deserializing the object from its internal representation.
+            // rmi.0E=An IOException occurred while deserializing the object from its internal representation.
             throw new RemoteException(Messages.getString("rmi.0E")); //$NON-NLS-1$
         } catch (ClassNotFoundException cnfe) {
-            // rmi.0F=A ClassNotFoundException occured while deserializing the object from its internal representation.
+            // rmi.0F=A ClassNotFoundException occurred while deserializing the object from its internal representation.
             throw new RemoteException(Messages.getString("rmi.0F")); //$NON-NLS-1$
         }
     }

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/java/rmi/server/RMIClassLoader.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/java/rmi/server/RMIClassLoader.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/java/rmi/server/RMIClassLoader.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/java/rmi/server/RMIClassLoader.java Sun Dec 24 14:29:13 2006
@@ -201,7 +201,7 @@
      *
      * @return provider obtained from default resource
      *
-     * @throws IOException if any I/O error occured while trying to read
+     * @throws IOException if any I/O error occurred while trying to read
      *         provider name from default resource
      */
     private static String getSpiFromResource() throws IOException {

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/java/rmi/server/RemoteStub.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/java/rmi/server/RemoteStub.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/java/rmi/server/RemoteStub.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/java/rmi/server/RemoteStub.java Sun Dec 24 14:29:13 2006
@@ -49,7 +49,7 @@
 
     /**
      * @com.intel.drl.spec_ref
-     * @deprecated This method is depreacted since Java v1.2. The constructor
+     * @deprecated This method is deprecated since Java v1.2. The constructor
      *  {@link #RemoteStub(java.rmi.server.RemoteRef)} should be used instead.
      */
     @Deprecated

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/java/rmi/server/UnicastRemoteObject.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/java/rmi/server/UnicastRemoteObject.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/java/rmi/server/UnicastRemoteObject.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/java/rmi/server/UnicastRemoteObject.java Sun Dec 24 14:29:13 2006
@@ -128,9 +128,9 @@
      *        method because it returns RemoteStub class (but Proxy class could
      *        not be casted to it)
      *
-     * @return stub for exportec object
+     * @return stub for exported object
      *
-     * @throws RemoteException if any error occured while exporting object
+     * @throws RemoteException if any error occurred while exporting object
      */
     private static Remote exportObject(Remote obj,
                                        int port,

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/DefaultRMIClassLoaderSpi.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/DefaultRMIClassLoaderSpi.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/DefaultRMIClassLoaderSpi.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/DefaultRMIClassLoaderSpi.java Sun Dec 24 14:29:13 2006
@@ -423,7 +423,7 @@
     /*
      * Finds loader in classloaders table. Returns it as a result if it's not
      * null, otherwise creates URLLoader, adds it to the table and returns it
-     * as a result. Checks persmission on found/created loader.
+     * as a result. Checks permission on found/created loader.
      *
      * @param codebase list of URLs separated by spaces
      *
@@ -666,7 +666,7 @@
 
 
     /*
-     * This class is a subclass of URLClassLoader. It containts annotations for
+     * This class is a subclass of URLClassLoader. It contains annotations for
      * classes and also permissions to be checked if requested.
      */
     private static class URLLoader extends URLClassLoader {

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/MarshalledObjectInputStream.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/MarshalledObjectInputStream.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/MarshalledObjectInputStream.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/MarshalledObjectInputStream.java Sun Dec 24 14:29:13 2006
@@ -48,7 +48,7 @@
      * @param objBytes serialized objects array
      * @param locBytes annotations for serialized objects
      *
-     * @throws IOException if an I/O error occured during streams initialization
+     * @throws IOException if an I/O error occurred during streams initialization
      */
     public MarshalledObjectInputStream(byte[] objBytes, byte[] locBytes)
             throws IOException {

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/MarshalledObjectOutputStream.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/MarshalledObjectOutputStream.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/MarshalledObjectOutputStream.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/MarshalledObjectOutputStream.java Sun Dec 24 14:29:13 2006
@@ -52,7 +52,7 @@
      *
      * @param out underlying OutputStream
      *
-     * @throws IOException if an I/O error occured during stream initialization
+     * @throws IOException if an I/O error occurred during stream initialization
      */
     public MarshalledObjectOutputStream(OutputStream out) throws IOException {
         super(out);

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/activation/ActivationGroupImpl.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/activation/ActivationGroupImpl.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/activation/ActivationGroupImpl.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/activation/ActivationGroupImpl.java Sun Dec 24 14:29:13 2006
@@ -76,7 +76,7 @@
      * ActivationGroupID <br>
      * ActivationGroupDesc <br>
      * incarnation The parameters needed to create ActivationGroup correctly are
-     * passed through the stardard input stream in the following order: <br>
+     * passed through the standard input stream in the following order: <br>
      * ActivationGroupID -> ActivationGroupDesc -> incarnation
      */
     public static void main(String args[]) {

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/activation/Rmid.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/activation/Rmid.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/activation/Rmid.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/activation/Rmid.java Sun Dec 24 14:29:13 2006
@@ -97,7 +97,7 @@
  * files: snapshot.rmid and delta.rmid. snapshot.rmid contains the
  * snapshot of the structure that contains information about Activation
  * Groups and Activatable Objects registered in this RMID and delta.rmid
- * reflects the changes occured since last snapshot.
+ * reflects the changes occurred since last snapshot.
  *
  * The objects that are saved in Snapshot:
  * <UL>

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/client/ClientConnection.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/client/ClientConnection.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/client/ClientConnection.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/client/ClientConnection.java Sun Dec 24 14:29:13 2006
@@ -75,7 +75,7 @@
      * @param s Connected socket
      * @param ep server's endpoint
      *
-     * @throws RemoteException if any I/O error occured during connection
+     * @throws RemoteException if any I/O error occurred during connection
      *         creation
      */
     public ClientConnection(Socket s, Endpoint ep) throws RemoteException {
@@ -125,18 +125,18 @@
      *
      * @return acknowledged protocol number
      *
-     * @throws RemoteException if any I/O exception occured during protocol
+     * @throws RemoteException if any I/O exception occurred during protocol
      *         acknowledgement
      */
     protected abstract int serverProtocolAck() throws RemoteException;
 
     /**
-     * Writes RMI protocol header and RMI protocol vertion to the open
+     * Writes RMI protocol header and RMI protocol version to the open
      * OutputStream.
      *
      * @param dout DataOutputStream to write header to
      *
-     * @throws RemoteException if any I/O error occured while writing header
+     * @throws RemoteException if any I/O error occurred while writing header
      */
     protected void writeHeader(DataOutputStream dout) throws RemoteException {
         try {
@@ -207,7 +207,7 @@
     /**
      * By default flushes output stream of this connection.
      *
-     * @throws IOException if any I/O error occured
+     * @throws IOException if any I/O error occurred
      */
     public void releaseOutputStream() throws IOException {
         out.flush();

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/client/ClientConnectionManager.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/client/ClientConnectionManager.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/client/ClientConnectionManager.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/client/ClientConnectionManager.java Sun Dec 24 14:29:13 2006
@@ -82,7 +82,7 @@
      *
      * @return opened connection
      *
-     * @throws RemoteException if any error occured while obtaining connection
+     * @throws RemoteException if any error occurred while obtaining connection
      */
     public static ClientConnection getConnection(Endpoint ep)
             throws RemoteException {

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/client/ClientRemoteCall.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/client/ClientRemoteCall.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/client/ClientRemoteCall.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/client/ClientRemoteCall.java Sun Dec 24 14:29:13 2006
@@ -83,7 +83,7 @@
      *
      * @return ObjectInputStream to read objects from
      *
-     * @throws IOException if an I/O error occured during stream construction
+     * @throws IOException if an I/O error occurred during stream construction
      */
     public ObjectInput getInputStream() throws IOException {
         if (oin == null) {
@@ -98,7 +98,7 @@
      *
      * @return ObjectOutputStream to write objects to
      *
-     * @throws IOException if an I/O error occured during stream construction
+     * @throws IOException if an I/O error occurred during stream construction
      */
 
     public ObjectOutput getOutputStream() throws IOException {
@@ -223,11 +223,11 @@
         try {
             obj = oin.readObject();
         } catch (IOException ioe) {
-            // rmi.3C=IOException occured while unmarshalling returned exception
+            // rmi.3C=IOException occurred while unmarshalling returned exception
             throw new UnmarshalException(Messages.getString("rmi.3C"), ioe); //$NON-NLS-1$
                     
         } catch (ClassNotFoundException cnfe) {
-            // rmi.3D=ClassNotFoundException occured while unmarshalling returned exception
+            // rmi.3D=ClassNotFoundException occurred while unmarshalling returned exception
             throw new UnmarshalException(Messages.getString("rmi.3D"), cnfe); //$NON-NLS-1$
         }
 

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/ClassList.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/ClassList.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/ClassList.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/ClassList.java Sun Dec 24 14:29:13 2006
@@ -212,7 +212,7 @@
     public void add(Class cls) {
         boolean exist = false;
 
-        // Do not pre-caclculate size, it will change.
+        // Do not pre-calculate size, it will change.
         for (int i = 0; i < vector.size(); i++) {
             Class element = (Class) vector.elementAt(i);
 
@@ -286,7 +286,7 @@
     public void remove(Class cls) {
         boolean changed = false;
 
-        // Do not pre-caclculate size, it will change.
+        // Do not pre-calculate size, it will change.
         for (int i = 0; i < vector.size(); i++) {
             Class element = (Class) vector.elementAt(i);
 

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/JavaCompiler.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/JavaCompiler.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/JavaCompiler.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/JavaCompiler.java Sun Dec 24 14:29:13 2006
@@ -176,7 +176,7 @@
      *
      * @param   pattern
      *          Pattern (regular expression)
-     *          describing the file that has to be retutned.
+     *          describing the file that has to be returned.
      *          The first file matching this pattern would be returned.
      *
      * @param   name

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/RMIHash.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/RMIHash.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/RMIHash.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/RMIHash.java Sun Dec 24 14:29:13 2006
@@ -40,7 +40,7 @@
 
 
 /**
- * Generates class and method hash codes neccessary for RMI.
+ * Generates class and method hash codes necessary for RMI.
  *
  * @author  Vasily Zakharov
  * @version $Revision: 1.1.2.2 $

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/RMILog.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/RMILog.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/RMILog.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/RMILog.java Sun Dec 24 14:29:13 2006
@@ -245,7 +245,7 @@
      * @param levelStr String to be parsed
      *
      * @return parsed Level or Level.OFF if the given string is null or an
-     *         error occured while it's parsing
+     *         error occurred while it's parsing
      */
     public static Level parseLevelString(String levelStr) {
         if (levelStr == null) {
@@ -279,7 +279,7 @@
     }
 
     /**
-     * Checks if underlying logger whould log a message with the specified
+     * Checks if underlying logger would log a message with the specified
      * level.
      *
      * @param l Logging level to be checked

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/RMIUtil.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/RMIUtil.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/RMIUtil.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/common/RMIUtil.java Sun Dec 24 14:29:13 2006
@@ -472,7 +472,7 @@
      * @return  List of remote interfaces for the specified class.
      *
      * @throws  IllegalArgumentException
-     *          If some error occured while creating the list.
+     *          If some error occurred while creating the list.
      */
     public static String[] getRemoteInterfacesNames(Class cls)
             throws IllegalArgumentException {
@@ -501,7 +501,7 @@
      *          and having method hashes as keys.
      *
      * @throws  RMIHashException
-     *          If error occured while calculating method hash.
+     *          If error occurred while calculating method hash.
      */
     public static Map getRemoteMethods(Class cls) throws RMIHashException {
         Map map = new HashMap();

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/compiler/ClassStub.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/compiler/ClassStub.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/compiler/ClassStub.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/compiler/ClassStub.java Sun Dec 24 14:29:13 2006
@@ -891,10 +891,10 @@
         }
 
         /**
-         * Returns stub imlementation for this method
+         * Returns stub implementation for this method
          * (Stub v1.1/v1.2/vCompat).
          *
-         * @return  Stub imlementation for this method.
+         * @return  Stub implementation for this method.
          */
         String getStubImpl() {
             return (getStubImplHeader()
@@ -910,10 +910,10 @@
         }
 
         /**
-         * Returns header for the stub implementaton for this method
+         * Returns header for the stub implementation for this method
          * (Stub v1.1/v1.2/vCompat).
          *
-         * @return  Stub imlementation header for this method.
+         * @return  Stub implementation header for this method.
          */
         private String getStubImplHeader() {
             StringBuffer buffer = new StringBuffer(indenter.indent()
@@ -943,10 +943,10 @@
         }
 
         /**
-         * Returns the stub implementaton code section source for this method
+         * Returns the stub implementation code section source for this method
          * (Stub v1.1/vCompat).
          *
-         * @return  Stub imlementation code for this method.
+         * @return  Stub implementation code for this method.
          */
         private String getStubImplCodeV11() {
             StringBuffer buffer = new StringBuffer(indenter.indent()
@@ -1010,10 +1010,10 @@
         }
 
         /**
-         * Returns the stub implementaton code section source for this method
+         * Returns the stub  implementation code section source for this method
          * (Stub v1.2/vCompat).
          *
-         * @return  Stub imlementation code for this method.
+         * @return  Stub implementation code for this method.
          */
         private String getStubImplCodeV12() {
             StringBuffer buffer = new StringBuffer(indenter.indent());
@@ -1051,10 +1051,10 @@
         }
 
         /**
-         * Returns the stub implementaton catch block for this method
+         * Returns the stub implementation catch block for this method
          * (Stub v1.1/v1.2/vCompat).
          *
-         * @return  Stub imlementation catch block for this method.
+         * @return  Stub implementation catch block for this method.
          */
         private String getStubImplCatchBlock() {
             StringBuffer buffer = new StringBuffer();

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/compiler/RMICompiler.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/compiler/RMICompiler.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/compiler/RMICompiler.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/compiler/RMICompiler.java Sun Dec 24 14:29:13 2006
@@ -113,7 +113,7 @@
     private final boolean verbose;
 
     /**
-     * Option: recompile dependend classes.
+     * Option: recompile dependent classes.
      * (<code>-depend</code>).
      */
     private final boolean depend;
@@ -144,7 +144,7 @@
      *
      * We use {@link Object} array to store either {@link String}
      * or {@link Class} objects because we don't want to resolve all the class
-     * names in the beginning - to avoid one incorrecly spelled class name
+     * names in the beginning - to avoid one incorrectly spelled class name
      * preventing generation of stubs for other specified classes.
      */
     private Object[] classes;
@@ -349,7 +349,7 @@
         javacOptionsList.add(optionNoWarnings);
 
         // Parse arguments, adjust values of option fields,
-        // add neccessary options to javacOptionsList.
+        // add necessary options to javacOptionsList.
         for (int i = 0; i < numArgs; i++) {
             String arg = args[i].intern();
 
@@ -676,7 +676,7 @@
             }
         } finally {
 
-            // Remove generated stub and skeleton files even if exception arised
+            // Remove generated stub and skeleton files even if exception arose
             if (!keepSources) {
                 for (int i = 0; i < filesNum; i++) {
                     stubFiles[i].delete();
@@ -764,7 +764,7 @@
      *              by <code>%s</code> substrings.
      *
      * @param       arg
-     *              Argument. Each occurence of <code>%s</code>
+     *              Argument. Each occurrence of <code>%s</code>
      *              in <code>message</code> is replaced with this string.
      *
      * @throws      RMICompilerException
@@ -780,7 +780,7 @@
      * Produces warning message.
      *
      * @param       tag
-     *              Warning tag. Used to track warnings. Also, each occurence
+     *              Warning tag. Used to track warnings. Also, each occurrence
      *              of <code>%s</code> in <code>message</code> is replaced
      *              with this string.
      *

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/compiler/RmicUtil.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/compiler/RmicUtil.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/compiler/RmicUtil.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/compiler/RmicUtil.java Sun Dec 24 14:29:13 2006
@@ -231,7 +231,7 @@
      * @param   packageName
      *          Package name (for subdirectory).
      *
-     * @return  File object for a directoty like this:
+     * @return  File object for a directory like this:
      *          <code>baseDir/my/java/package</code>.
      *
      * @throws  RMICompilerException

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/internal/nls/messages.properties
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/internal/nls/messages.properties?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/internal/nls/messages.properties (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/internal/nls/messages.properties Sun Dec 24 14:29:13 2006
@@ -29,8 +29,8 @@
 rmi.0B=Stub class initialization failed: java.rmi.activation.ActivationGroup_Stub
 rmi.0C=Undeclared checked exception
 rmi.0D=The default group for this JVM is inactive.
-rmi.0E=An IOException occured while deserializing the object from its internal representation.
-rmi.0F=A ClassNotFoundException occured while deserializing the object from its internal representation.
+rmi.0E=An IOException occurred while deserializing the object from its internal representation.
+rmi.0F=A ClassNotFoundException occurred while deserializing the object from its internal representation.
 rmi.10=The groupID can't be null.
 rmi.11=The ActivationGroup for this VM already exists.
 rmi.12=Unable to create group.
@@ -75,8 +75,8 @@
 rmi.39=Unknown call status response: {0}
 rmi.3A=Unable to read call return header: 
 rmi.3B=Unknown call result response: {0}
-rmi.3C=IOException occured while unmarshalling returned exception
-rmi.3D=ClassNotFoundException occured while unmarshalling returned exception
+rmi.3C=IOException occurred while unmarshalling returned exception
+rmi.3D=ClassNotFoundException occurred while unmarshalling returned exception
 rmi.3E=Remote method threw unexpected exception
 rmi.3F=Not Exception type thrown: {0}
 rmi.40=Unable to establish connection to server
@@ -118,17 +118,17 @@
 rmi.64=Unable to export object on port {0}
 rmi.65=Skeleton class not found.
 rmi.66=Method with hash = {0} not found.
-rmi.67=Error occured while marshalling return value
+rmi.67=Error occurred while marshalling return value
 rmi.68=Stub {0} not found.
-rmi.69=RemoteException occured while unmarshalling arguments
-rmi.6A=IOException occured while unmarshalling arguments
-rmi.6B=ClassNotFoundException occured while unmarshalling arguments
-rmi.6C=Error occured while unmarshalling arguments
-rmi.6D=Error occured while remote method invocation
-rmi.6E=RemoteException occured while remote method invocation
-rmi.6F=I/O error occured while marshalling arguments
-rmi.70=IOException occured while unmarshalling return value
-rmi.71=ClassNotFoundException occured while unmarshalling return value
+rmi.69=RemoteException occurred while unmarshalling arguments
+rmi.6A=IOException occurred while unmarshalling arguments
+rmi.6B=ClassNotFoundException occurred while unmarshalling arguments
+rmi.6C=Error occurred while unmarshalling arguments
+rmi.6D=Error occurred while remote method invocation
+rmi.6E=RemoteException occurred while remote method invocation
+rmi.6F=I/O error occurred while marshalling arguments
+rmi.70=IOException occurred while unmarshalling return value
+rmi.71=ClassNotFoundException occurred while unmarshalling return value
 rmi.72=Unable to marshal call header
 rmi.73=Instantiation failed.
 rmi.74=Unable to read Object ID

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/ActivatableRef.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/ActivatableRef.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/ActivatableRef.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/ActivatableRef.java Sun Dec 24 14:29:13 2006
@@ -164,7 +164,7 @@
 
     /**
      * If the internal remote reference of this ActivatableRef is null, the activatable object is activated using
-     * ActivationID.activate() methiod. After that the remote call is delegated to the ref, by means of calling its 'invoke' method.
+     * ActivationID.activate() method. After that the remote call is delegated to the ref, by means of calling its 'invoke' method.
      */
     public Object invoke(Remote obj, Method method, Object[] params, long opnum)
             throws Exception {
@@ -195,7 +195,7 @@
         /*
          * If the group's VM was killed(or something bad happened to it) we may have stale activatable reference to the object.
          * In this case rref.invoke() will throw 3 types of Exceptions: ConnectException, ConnectIOException and UnknownObjectException
-         * which should be catched and activation group should be activated again.
+         * which should be caught and activation group should be activated again.
          */
         try {
             return rref.invoke(obj, method, params, opnum);
@@ -226,7 +226,7 @@
     }
 
     /**
-     * Standart remoteEquals implementaion.
+     * Standard remoteEquals implementation.
      *
      * @param ref
      *

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/ActivatableServerRef.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/ActivatableServerRef.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/ActivatableServerRef.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/ActivatableServerRef.java Sun Dec 24 14:29:13 2006
@@ -47,7 +47,7 @@
     /**
      * Constructor intended to create ActivatableServerRef on the given port.
      *
-     * @param aid Activation identificator of this ActivatableRef
+     * @param aid Activation identifier of this ActivatableRef
      * @param port Port on which ActivatableServerRef will be exported.
      * @param csf Client socket factory.
      * @param ssf Server socket factory.
@@ -62,7 +62,7 @@
 
     /**
      * Constructor intended to create ActivatableServerRef on the given port.
-     * @param aid Activation identificator of this ActivatableRef
+     * @param aid Activation identifier of this ActivatableRef
      * @param port Port on which ActivatableServerRef will be exported.
      */
     public ActivatableServerRef(ActivationID aid, int port) {

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/UnicastRef.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/UnicastRef.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/UnicastRef.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/UnicastRef.java Sun Dec 24 14:29:13 2006
@@ -144,7 +144,7 @@
                     }
                 }
             } catch (IOException ioe) {
-                // rmi.6F=I/O error occured while marshalling arguments
+                // rmi.6F=I/O error occurred while marshalling arguments
                 throw new MarshalException(Messages.getString("rmi.6F"), ioe); //$NON-NLS-1$
             }
 
@@ -160,10 +160,10 @@
                 try {
                     toReturn = oin.readRMIObject(m.getReturnType());
                 } catch (IOException ioe) {
-                    // rmi.70=IOException occured while unmarshalling return value
+                    // rmi.70=IOException occurred while unmarshalling return value
                     throw new UnmarshalException(Messages.getString("rmi.70"), ioe); //$NON-NLS-1$
                 } catch (ClassNotFoundException cnfe) {
-                    // rmi.71=ClassNotFoundException occured while unmarshalling return value
+                    // rmi.71=ClassNotFoundException occurred while unmarshalling return value
                     throw new UnmarshalException(Messages.getString("rmi.71"), cnfe); //$NON-NLS-1$
                 }
             }
@@ -187,7 +187,7 @@
      *
      * @param out the stream to write the object to
      *
-     * @throws IOException if any I/O error occured or class is not serializable
+     * @throws IOException if any I/O error occurred or class is not serializable
      */
     public void writeExternal(ObjectOutput out) throws IOException {
         ep.writeExternal(out, false);
@@ -199,7 +199,7 @@
      *
      * @param in the stream to read data from
      *
-     * @throws IOException if any I/O error occured
+     * @throws IOException if any I/O error occurred
      * @throws ClassNotFoundException if class could not be loaded by current
      *         class loader
      */

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/UnicastRef2.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/UnicastRef2.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/UnicastRef2.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/UnicastRef2.java Sun Dec 24 14:29:13 2006
@@ -99,7 +99,7 @@
      *
      * @param out the stream to write the object to
      *
-     * @throws IOException if any I/O error occured or class is not serializable
+     * @throws IOException if any I/O error occurred or class is not serializable
      */
     public void writeExternal(ObjectOutput out) throws IOException {
         ep.writeExternal(out, true);
@@ -111,7 +111,7 @@
      *
      * @param in the stream to read data from
      *
-     * @throws IOException if any I/O error occured
+     * @throws IOException if any I/O error occurred
      * @throws ClassNotFoundException if class could not be loaded by current
      *         class loader
      */

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/UnicastServerRef.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/UnicastServerRef.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/UnicastServerRef.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/remoteref/UnicastServerRef.java Sun Dec 24 14:29:13 2006
@@ -98,7 +98,7 @@
      */
     protected ServerConnectionManager mgr;
 
-    // The name of Remote class for loggin purposes.
+    // The name of Remote class for login purposes.
     private String implClassName = null;
 
     // Log where to write server-side log of remote calls.
@@ -200,7 +200,7 @@
         String host = ServerConnectionManager.getClientHost();
 
         if (host == null) {
-            // rmi.5B=There are no in-progress RMI calls in the current thead.
+            // rmi.5B=There are no in-progress RMI calls in the current thread.
             throw new ServerNotActiveException(Messages.getString("rmi.5B")); //$NON-NLS-1$
         }
         return host;
@@ -244,7 +244,7 @@
      * @param isSystem if true then existence of this object will not prevent
      *        VM from exiting (for example, for rmiregistry)
      *
-     * @throws RemoteException if any exception occured while trying to export
+     * @throws RemoteException if any exception occurred while trying to export
      *         the object
      */
     public Remote exportObject(Remote obj,
@@ -360,7 +360,7 @@
     /**
      * Returns true if force parameter is false and there are no in-progress
      * calls to the object handled by this ref and false otherwise. This method
-     * could be overriden by subclasses to "really" unexport handled object.
+     * could be overridden by subclasses to "really" unexport handled object.
      *
      * @param force if true then we may not care about active calls
      *
@@ -385,7 +385,7 @@
      *
      * @param call RemoteCall
      *
-     * @throws IOException if any I/O error occured during remote method call
+     * @throws IOException if any I/O error occurred during remote method call
      */
     public void processCall(RemoteCall call) throws IOException {
         // read method and parameters
@@ -455,7 +455,7 @@
             }
             oout.flush();
         } catch (Error er) {
-            // rmi.67=Error occured while marshalling return value
+            // rmi.67=Error occurred while marshalling return value
             throw new ServerError(Messages.getString("rmi.67"), er); //$NON-NLS-1$
         }
     }
@@ -468,10 +468,10 @@
      *        failure or silently return null
      *
      * @return loaded stub or null if throwException is false and any failure
-     *         occured during stub loading
+     *         occurred during stub loading
      *
      * @throws StubNotFoundException if throwException parameter is true and any
-     *         failure occured during stub loading
+     *         failure occurred during stub loading
      */
     protected Class loadStubClass(Class c, boolean throwException)
             throws StubNotFoundException {
@@ -498,7 +498,7 @@
      *
      * @param c Class whose skel should be loaded and instantiated
      *
-     * @return created skel class or null if any Exception occured during
+     * @return created skel class or null if any Exception occurred during
      *         skel loading or instantiating
      */
     protected Skeleton getSkelInstance(Class c) {
@@ -546,16 +546,16 @@
                 params[i] = oin.readRMIObject(paramTypes[i]);
             }
         } catch (RemoteException re) {
-            // rmi.69=RemoteException occured while unmarshalling arguments
+            // rmi.69=RemoteException occurred while unmarshalling arguments
             throw new ServerException(Messages.getString("rmi.69"), re); //$NON-NLS-1$
         } catch (IOException ioe) {
-            // rmi.6A=IOException occured while unmarshalling arguments
+            // rmi.6A=IOException occurred while unmarshalling arguments
             throw new UnmarshalException(Messages.getString("rmi.6A"), ioe); //$NON-NLS-1$
         } catch (ClassNotFoundException cnfe) {
-            // rmi.6B=ClassNotFoundException occured while unmarshalling arguments
+            // rmi.6B=ClassNotFoundException occurred while unmarshalling arguments
             throw new UnmarshalException(Messages.getString("rmi.6B"), cnfe); //$NON-NLS-1$
         } catch (Error er) {
-            // rmi.6C=Error occured while unmarshalling arguments
+            // rmi.6C=Error occurred while unmarshalling arguments
             throw new ServerError(Messages.getString("rmi.6C"), er); //$NON-NLS-1$
         }
         return params;
@@ -575,10 +575,10 @@
         logServerException(m, t);
 
         if (t instanceof Error) {
-            // rmi.6D=Error occured while remote method invocation
+            // rmi.6D=Error occurred while remote method invocation
             preparedEx = new ServerError(Messages.getString("rmi.6D"), (Error) t); //$NON-NLS-1$
         } else if (t instanceof RemoteException) {
-            // rmi.6E=RemoteException occured while remote method invocation
+            // rmi.6E=RemoteException occurred while remote method invocation
             preparedEx = new ServerException(Messages.getString("rmi.6E"), //$NON-NLS-1$
                     (RemoteException) t);
         } else {

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ClientDGC.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ClientDGC.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ClientDGC.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ClientDGC.java Sun Dec 24 14:29:13 2006
@@ -311,7 +311,7 @@
         // Base time for calculating renew time in case of failed dirty calls
         private long failedRenewBaseDuration = 0;
 
-        // Lease duration returned by the latest successfull DGC.dirty call.
+        // Lease duration returned by the latest successful DGC.dirty call.
         private long latestLeaseDuration = 0;
 
         /*
@@ -461,7 +461,7 @@
 
     /*
      * Auxiliary thread detecting remote objects which where garbage-collected
-     * and spawning the thread callling DGC.clean() method.
+     * and spawning the thread calling DGC.clean() method.
      */
     private static class RemovedObjectsDetector implements Runnable {
 

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/DGCImpl.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/DGCImpl.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/DGCImpl.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/DGCImpl.java Sun Dec 24 14:29:13 2006
@@ -203,7 +203,7 @@
 
 
     /*
-     * Auxiliary class checking expiration times and removind expired entries
+     * Auxiliary class checking expiration times and removing expired entries
      * from the list of active objects.
      */
     private class ExpirationTracker implements Runnable {

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ExportManager.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ExportManager.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ExportManager.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ExportManager.java Sun Dec 24 14:29:13 2006
@@ -101,7 +101,7 @@
      *
      * @return stub for exported object
      *
-     * @throws RemoteException if any exception occured while exporting
+     * @throws RemoteException if any exception occurred while exporting
      *         specified remote object
      */
     public static Remote exportObject(Remote obj,
@@ -133,7 +133,7 @@
      *
      * @return stub for exported object
      *
-     * @throws RemoteException if any exception occured while exporting
+     * @throws RemoteException if any exception occurred while exporting
      *         specified remote object
      */
     public static Remote exportObject(Remote obj,
@@ -267,7 +267,7 @@
     }
 
     /*
-     * Decrease the number of active callse by one.
+     * Decrease the number of active calls by one.
      */
     static void removeActiveCall() {
         synchronized (callsLock) {
@@ -289,7 +289,7 @@
 
 
     /*
-     * Thread removind objects from the table when they are scheduled for GC.
+     * Thread removing objects from the table when they are scheduled for GC.
      * It blocks VM from exiting as it's run with setDaemon(false).
      */
     private static class Scavenger implements Runnable {

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/RMIObjectInfo.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/RMIObjectInfo.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/RMIObjectInfo.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/RMIObjectInfo.java Sun Dec 24 14:29:13 2006
@@ -73,7 +73,7 @@
 
     /*
      * Constructs RemoteObjectInfo holding the specified information.
-     * The ClassLoader for dispatching calls is chosed using the following
+     * The ClassLoader for dispatching calls is chosen using the following
      * rules:
      * 1) If current thread context ClassLoader is null, then ClassLoader
      *    which loads Class of remote object will be the ClassLoader for
@@ -85,7 +85,7 @@
      *    of the ClassLoader which loads Class of remote object, then
      *    current thread context ClassLoader will be the ClassLoader for for
      *    dispatching calls.
-     * 4) Otherwise ClassLoader which loads Class of remkote object will
+     * 4) Otherwise ClassLoader which loads Class of remote object will
      *    be the ClassLoader fo dispatching calls.
      *
      * @param ref reference to remote object

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/RMIReference.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/RMIReference.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/RMIReference.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/RMIReference.java Sun Dec 24 14:29:13 2006
@@ -31,7 +31,7 @@
 
 /**
  * Extension of WeakReference. It could contain strong reference to the object.
- * Also hashCode() and equals() methods are overriden. This class is used for
+ * Also hashCode() and equals() methods are overridden. This class is used for
  * storing exported rmi objects.
  *
  * @author  Mikhail A. Markov

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/RemoteRefBase.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/RemoteRefBase.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/RemoteRefBase.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/RemoteRefBase.java Sun Dec 24 14:29:13 2006
@@ -45,7 +45,7 @@
 
     private static final long serialVersionUID = 358378173612121423L;
 
-    /** Endpoind this handle refers to. */
+    /** Endpoint this handle refers to. */
     protected Endpoint ep;
 
     /** Object ID of remote object. */
@@ -104,7 +104,7 @@
      *
      * @param in the stream to read data from
      *
-     * @throws IOException if any I/O error occured
+     * @throws IOException if any I/O error occurred
      * @throws ClassNotFoundException if class could not be loaded by current
      *         class loader
      */
@@ -136,7 +136,7 @@
      *
      * @param out the stream to write the object to
      *
-     * @throws IOException if any I/O error occured or class is not serializable
+     * @throws IOException if any I/O error occurred or class is not serializable
      */
     protected void writeCommon(ObjectOutput out) throws IOException {
         objId.write(out);

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ServerConnection.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ServerConnection.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ServerConnection.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ServerConnection.java Sun Dec 24 14:29:13 2006
@@ -85,7 +85,7 @@
      * @param s Socket connected to the client
      * @param mgr ServerConnectionManager managing this connection
      *
-     * @throws IOException if an I/O error occured during getting
+     * @throws IOException if an I/O error occurred during getting
      *         input/output streams from specified socket
      */
     public ServerConnection(Socket s, ServerConnectionManager mgr)
@@ -102,7 +102,7 @@
 
     /**
      * Acknowledges RMI protocol version, RMI protocol type etc. and wait for
-     * remote calls from client. After call message dispatch call to apropriate
+     * remote calls from client. After call message dispatch call to appropriate
      * UnicastServerRef for processing.
      */
     public void run() {
@@ -241,7 +241,7 @@
      *
      * @return acknowledged protocol number
      *
-     * @throws RemoteException if any I/O exception occured during protocol
+     * @throws RemoteException if any I/O exception occurred during protocol
      *         acknowledgement
      */
     protected abstract int clientProtocolAck() throws IOException;
@@ -255,7 +255,7 @@
      * @return 0x50 code if this code is received from the client or -1 if
      *         the socket was closed while waiting for CALL_MSG code
      *
-     * @throws IOException if any I/O error occured while communicating with
+     * @throws IOException if any I/O error occurred while communicating with
      *         client
      */
     protected abstract int waitCallMsg() throws IOException;

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ServerConnectionManager.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ServerConnectionManager.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ServerConnectionManager.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ServerConnectionManager.java Sun Dec 24 14:29:13 2006
@@ -94,7 +94,7 @@
      *
      * @param sref server-side handle for exported remote object
      *
-     * @throws IOException if any I/O error occured during opening ServerSocket
+     * @throws IOException if any I/O error occurred during opening ServerSocket
      */
     private ServerConnectionManager(Endpoint localEp)
             throws IOException {
@@ -110,7 +110,7 @@
      *
      * @return found (created) ServerConnectionManager
      *
-     * @throws IOException and and I/O error occured during manager creation
+     * @throws IOException and and I/O error occurred during manager creation
      */
     public static synchronized ServerConnectionManager getMgr(Endpoint ep)
             throws IOException {
@@ -196,7 +196,7 @@
                     }
                 } else {
                     // We will try to immediately accept another client again,
-                    // but if we have a bad client wich fails our accept tries
+                    // but if we have a bad client which fails our accept tries
                     // for a number of times, we should sleep for a while.
                     if (failedAcceptsNum >= 5) {
                         try {
@@ -234,7 +234,7 @@
     }
 
     /**
-     * Decrease the number of active callse by one.
+     * Decrease the number of active calls by one.
      */
     protected void removeActiveCall() {
         synchronized (callsLock) {
@@ -251,7 +251,7 @@
      *
      * @return connection to the remote client
      *
-     * @throws IOException if any I/O error occured while starting connection
+     * @throws IOException if any I/O error occurred while starting connection
      */
     private ServerConnection startConnection(Socket s)
             throws IOException {

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ServerRemoteCall.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ServerRemoteCall.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ServerRemoteCall.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/server/ServerRemoteCall.java Sun Dec 24 14:29:13 2006
@@ -82,7 +82,7 @@
      *
      * @return ObjectInputStream to read objects from
      *
-     * @throws IOException if an I/O error occured during stream construction
+     * @throws IOException if an I/O error occurred during stream construction
      */
     public ObjectInput getInputStream() throws IOException {
         if (oin == null) {
@@ -97,7 +97,7 @@
      *
      * @return ObjectOutputStream to write objects to
      *
-     * @throws IOException if an I/O error occured during stream construction
+     * @throws IOException if an I/O error occurred during stream construction
      */
 
     public ObjectOutput getOutputStream() throws IOException {
@@ -113,11 +113,11 @@
      * writes UID of the object (for DGC) and flushes the output stream.
      * This method could be called only once.
      *
-     * @param success if true - means that method call was successfull (i.e.
+     * @param success if true - means that method call was successful (i.e.
      *        with no exception) - return data description will be written to
      *        the output stream
      *
-     * @throws IOexception if an I/O error occured while writing to the stream
+     * @throws IOException if an I/O error occurred while writing to the stream
      * @throws StreamCorruptedException if this method has already been called
      */
     public ObjectOutput getResultStream(boolean success)

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/DefaultRMISocketFactory.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/DefaultRMISocketFactory.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/DefaultRMISocketFactory.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/DefaultRMISocketFactory.java Sun Dec 24 14:29:13 2006
@@ -214,7 +214,7 @@
      * Helper method: returns non-null RMIClientSocketFactory.
      * Returns specified RMIClientSocketFactory if it is not null; otherwise
      * returns result of getSocketFactory method call if it is not null;
-     * ottherwise returns result of getDefaultSocketFactory method call.
+     * otherwise returns result of getDefaultSocketFactory method call.
      *
      * @param csf RMIClientSocketFactory to check
      *
@@ -231,7 +231,7 @@
      * Helper method: returns non-null RMIServerSocketFactory.
      * Returns specified RMIServerSocketFactory if it is not null; otherwise
      * returns result of getSocketFactory method call if it is not null;
-     * ottherwise returns result of getDefaultSocketFactory method call.
+     * otherwise returns result of getDefaultSocketFactory method call.
      *
      * @param ssf RMIServerSocketFactory to check
      *

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/Endpoint.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/Endpoint.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/Endpoint.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/Endpoint.java Sun Dec 24 14:29:13 2006
@@ -267,7 +267,7 @@
      * @param out ObjectOutput to write this Endpoint to
      * @param writeCsf do we need to write client-side factory or not
      *
-     * @throws IOException if any I/O error occured during writing
+     * @throws IOException if any I/O error occurred during writing
      */
     public void writeExternal(ObjectOutput out, boolean writeCsf)
             throws IOException {
@@ -294,7 +294,7 @@
      *
      * @return created Endpoint
      *
-     * @throws IOException if any I/O error occured
+     * @throws IOException if any I/O error occurred
      * @throws ClassNotFoundException if class could not be loaded by current
      *         class loader
      */

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/RMIObjectInputStream.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/RMIObjectInputStream.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/RMIObjectInputStream.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/RMIObjectInputStream.java Sun Dec 24 14:29:13 2006
@@ -70,7 +70,7 @@
      *
      * @param in underlying InputStream
      *
-     * @throws IOException if an I/O error occured during stream initialization
+     * @throws IOException if an I/O error occurred during stream initialization
      */
     public RMIObjectInputStream(InputStream in) throws IOException {
         this (in, false);
@@ -84,7 +84,7 @@
      * @param isRCallStream true if this stream was created for handling
      *        a RemoteCall and false otherwise
      *
-     * @throws IOException if an I/O error occured during stream initialization
+     * @throws IOException if an I/O error occurred during stream initialization
      */
     public RMIObjectInputStream(InputStream in, boolean isRCallStream)
             throws IOException {
@@ -106,7 +106,7 @@
      *
      * @param streamCl annotated class
      *
-     * @throws IOException if an I/O exception occured
+     * @throws IOException if an I/O exception occurred
      * @throws ClassNotFoundException if class of a serialized object
      *         could not be found
      */
@@ -128,7 +128,7 @@
      *
      * @param interf array of interfaces which proxy class should implement
      *
-     * @throws IOException if an I/O exception occured
+     * @throws IOException if an I/O exception occurred
      * @throws ClassNotFoundException if class of a serialized object
      *         could not be found
      */
@@ -165,7 +165,7 @@
      *
      * @return object read from the stream
      *
-     * @throws IOException if an I/O error occured during deserialization
+     * @throws IOException if an I/O error occurred during deserialization
      * @throws ClassNotFoundException if class of a serialized object
      *         could not be found
      */

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/RMIObjectOutputStream.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/RMIObjectOutputStream.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/RMIObjectOutputStream.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/RMIObjectOutputStream.java Sun Dec 24 14:29:13 2006
@@ -69,7 +69,7 @@
      *
      * @param out underlying OutputStream
      *
-     * @throws IOException if an I/O error occured during stream initialization
+     * @throws IOException if an I/O error occurred during stream initialization
      */
     public RMIObjectOutputStream(OutputStream out) throws IOException {
         this(out, false);
@@ -83,7 +83,7 @@
      * @param isResultStream true if this stream was created
      *        in RemoteCall.getResultStream() method
      *
-     * @throws IOException if an I/O error occured during stream initialization
+     * @throws IOException if an I/O error occurred during stream initialization
      */
     public RMIObjectOutputStream(OutputStream out, boolean isResultStream)
             throws IOException {
@@ -173,7 +173,7 @@
      * @param obj object (possibly primitive) to be written to the stream
      * @param cl type of object to be written to the stream
      *
-     * @throws IOException if an I/O error occured during serialization
+     * @throws IOException if an I/O error occurred during serialization
      */
     public void writeRMIObject(Object obj, Class cl) throws IOException {
         if (cl.isPrimitive()) {
@@ -217,7 +217,7 @@
     /**
      * Writes DGC ack UID to this stream.
      *
-     * @throws IOException if any I/O error occured while writing
+     * @throws IOException if any I/O error occurred while writing
      */
     public void writeUID() throws IOException {
         uid.write(this);

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/proxy/HttpConnection.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/proxy/HttpConnection.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/proxy/HttpConnection.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/proxy/HttpConnection.java Sun Dec 24 14:29:13 2006
@@ -55,7 +55,7 @@
      *
      * @return acknowledged protocol number
      *
-     * @throws RemoteException if any I/O exception occured during protocol
+     * @throws RemoteException if any I/O exception occurred during protocol
      *         acknowledgement
      */
     protected int serverProtocolAck() throws RemoteException {

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/proxy/HttpServerConnection.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/proxy/HttpServerConnection.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/proxy/HttpServerConnection.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/proxy/HttpServerConnection.java Sun Dec 24 14:29:13 2006
@@ -54,7 +54,7 @@
      * @param s Socket connected to the client
      * @param mgr ConnectionManager managing this connection
      *
-     * @throws IOException if an I/O error occured during getting
+     * @throws IOException if an I/O error occurred during getting
      *         input/output streams from specified socket
      */
     public HttpServerConnection(Socket s, ServerConnectionManager mgr)

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/proxy/Proxy.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/proxy/Proxy.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/proxy/Proxy.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/proxy/Proxy.java Sun Dec 24 14:29:13 2006
@@ -161,7 +161,7 @@
 
     /**
      * Accesses {@link #PROXY_HOST_PROP} system property
-     * and retrives the proxy host name.
+     * and retrieves the proxy host name.
      *
      * @return  Proxy host name or <code>null</code> if proxy host is not set.
      */
@@ -180,7 +180,7 @@
 
     /**
      * Accesses {@link #PROXY_PORT_PROP} system property
-     * and retrives the proxy port number.
+     * and retrieves the proxy port number.
      *
      * @return  Proxy port number or {@link #HTTP_DEFAULT_PORT}
      *          if proxy port is not set.

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/tcp/TcpConnection.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/tcp/TcpConnection.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/tcp/TcpConnection.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/tcp/TcpConnection.java Sun Dec 24 14:29:13 2006
@@ -50,7 +50,7 @@
     // status of availability for remote calls
     private boolean available;
 
-    // lock object for synchtonization
+    // lock object for synchronization
     private class Lock {}
     private Object lock = new Lock();
 
@@ -82,7 +82,7 @@
      *
      * @return acknowledged protocol number
      *
-     * @throws RemoteException if any I/O exception occured during protocol
+     * @throws RemoteException if any I/O exception occurred during protocol
      *         acknowledgement
      */
     protected int serverProtocolAck() throws RemoteException {
@@ -110,7 +110,7 @@
             } catch (Exception ex) {
             }
 
-            // read protocol acknoledgement
+            // read protocol acknowledgement
             DataInputStream din = new DataInputStream(in);
             int ack = din.readByte();
 

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/tcp/TcpServerConnection.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/tcp/TcpServerConnection.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/tcp/TcpServerConnection.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/main/java/org/apache/harmony/rmi/transport/tcp/TcpServerConnection.java Sun Dec 24 14:29:13 2006
@@ -51,7 +51,7 @@
     protected static final RMILog tcpTransportLog = RMILog.getTcpTransportLog();
 
     /*
-     * The time used as an idle timeout for incomping connections (in ms).
+     * The time used as an idle timeout for incoming connections (in ms).
      * Default value is 2 * 3600 * 1000 ms (2 hours).
      */
     private static int readTimeout = ((Long) AccessController.doPrivileged(
@@ -64,7 +64,7 @@
      * @param s Socket connected to the client
      * @param mgr ConnectionManager managing this connection
      *
-     * @throws IOException if an I/O error occured during getting
+     * @throws IOException if an I/O error occurred during getting
      *         input/output streams from specified socket
      */
     public TcpServerConnection(Socket s, ServerConnectionManager mgr)

Modified: harmony/enhanced/classlib/trunk/modules/rmi/src/test/api/java/org/apache/harmony/rmi/MarshalledObjectTest.java
URL: http://svn.apache.org/viewvc/harmony/enhanced/classlib/trunk/modules/rmi/src/test/api/java/org/apache/harmony/rmi/MarshalledObjectTest.java?view=diff&rev=490076&r1=490075&r2=490076
==============================================================================
--- harmony/enhanced/classlib/trunk/modules/rmi/src/test/api/java/org/apache/harmony/rmi/MarshalledObjectTest.java (original)
+++ harmony/enhanced/classlib/trunk/modules/rmi/src/test/api/java/org/apache/harmony/rmi/MarshalledObjectTest.java Sun Dec 24 14:29:13 2006
@@ -161,7 +161,7 @@
 
 
     /**
-     * Auxilary empty class.
+     * Auxiliary empty class.
      */
     static class TestClass implements Serializable {
     }