You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@openjpa.apache.org by pc...@apache.org on 2006/07/14 01:45:02 UTC

svn commit: r421741 [4/15] - in /incubator/openjpa/trunk: openjpa-kernel-5/src/main/java/org/apache/openjpa/enhance/ openjpa-kernel/src/main/java/org/apache/openjpa/abstractstore/ openjpa-kernel/src/main/java/org/apache/openjpa/ant/ openjpa-kernel/src/...

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/EndTransactionListener.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/EndTransactionListener.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/EndTransactionListener.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/EndTransactionListener.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -16,7 +16,7 @@
 package org.apache.openjpa.event;
 
 /**
- * <p>Notified when transactions end.</p>
+ * Notified when transactions end.
  *
  * @author Patrick Linskey
  * @author Abe White
@@ -27,28 +27,28 @@
     /**
      * Notification that the next flush is for the transaction commit.
      *
-     * @see    TransactionEvent#BEFORE_COMMIT
+     * @see TransactionEvent#BEFORE_COMMIT
      */
     public void beforeCommit(TransactionEvent event);
 
     /**
      * Notification that a transaction has successfully committed.
      *
-     * @see    TransactionEvent#AFTER_COMMIT
+     * @see TransactionEvent#AFTER_COMMIT
      */
     public void afterCommit(TransactionEvent event);
 
     /**
      * Notification that a transaction has been rolled back.
      *
-     * @see    TransactionEvent#AFTER_ROLLBACK
+     * @see TransactionEvent#AFTER_ROLLBACK
      */
     public void afterRollback(TransactionEvent event);
 
     /**
      * Notification that state transitions are complete.
      *
-     * @see    TransactionEvent#AFTER_STATE_TRANSITIONS
+     * @see TransactionEvent#AFTER_STATE_TRANSITIONS
      */
     public void afterStateTransitions(TransactionEvent event);
 
@@ -56,15 +56,15 @@
      * Notification that a transaction has successfully committed and
      * the transaction is no longer active.
      *
-     * @see    TransactionEvent#AFTER_COMMIT_COMPLETE
+     * @see TransactionEvent#AFTER_COMMIT_COMPLETE
      */
     public void afterCommitComplete(TransactionEvent event);
 
     /**
-     *	Notification that a transaction has been rolled back and
-     *	the transaction is no longer active.
+     * Notification that a transaction has been rolled back and
+     * the transaction is no longer active.
      *
-     *	@see    TransactionEvent#AFTER_ROLLBACK_COMPLETE
+     * @see TransactionEvent#AFTER_ROLLBACK_COMPLETE
      */
     public void afterRollbackComplete(TransactionEvent event);
 }

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/ExceptionOrphanedKeyAction.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/ExceptionOrphanedKeyAction.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/ExceptionOrphanedKeyAction.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/ExceptionOrphanedKeyAction.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -21,8 +21,7 @@
 import org.apache.openjpa.util.ObjectNotFoundException;
 
 /**
- * <p>Throw a {@link ObjectNotFoundException} when an orphaned key
- * is discovered.</p>
+ * Throw a {@link ObjectNotFoundException} when an orphaned key is discovered.
  *
  * @author Abe White
  * @since 3.2.2

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/FlushTransactionListener.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/FlushTransactionListener.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/FlushTransactionListener.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/FlushTransactionListener.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -16,7 +16,7 @@
 package org.apache.openjpa.event;
 
 /**
- * <p>Notified on transaction flush.</p>
+ * Notified on transaction flush.
  *
  * @author Patrick Linskey
  * @author Abe White
@@ -27,14 +27,14 @@
     /**
      * Notification that a transaction is about to flush all object changes.
      *
-     * @see    TransactionEvent#BEFORE_FLUSH
+     * @see TransactionEvent#BEFORE_FLUSH
      */
     public void beforeFlush(TransactionEvent event);
 
     /**
      * Notification that a transaction has flushed all object changes.
      *
-     * @see    TransactionEvent#AFTER_FLUSH
+     * @see TransactionEvent#AFTER_FLUSH
      */
     public void afterFlush(TransactionEvent event);
 }

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/JMSRemoteCommitProvider.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/JMSRemoteCommitProvider.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/JMSRemoteCommitProvider.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/JMSRemoteCommitProvider.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -80,7 +80,7 @@
 
     /**
      * The number of times to attempt to reconnect after a JMS send exception
-     * is detected.  Defaults to 0, meaning no attempt to reconnect is made;
+     * is detected. Defaults to 0, meaning no attempt to reconnect is made;
      * the exception is logged and ignored.
      */
     public void setExceptionReconnectAttempts(int attempts) {
@@ -89,7 +89,7 @@
 
     /**
      * Set a map of properties to pass to the {@link InitialContext}
-     * constructor for JNDI lookups.  Implementation of
+     * constructor for JNDI lookups. Implementation of
      * {@link GenericConfigurable}.
      */
     public void setInto(Map m) {
@@ -102,8 +102,7 @@
     }
 
     /**
-     * Returns a new {@link Context} object for use by this
-     * provider.
+     * Returns a new {@link Context} object for use by this provider.
      */
     protected Context newContext()
         throws NamingException {
@@ -174,29 +173,27 @@
             // create a subscriber.
             TopicSubscriber s = _session.createSubscriber(topic, null,
                 /* noLocal: */ true);
-            MessageListener l = getMessageListener();
-            s.setMessageListener(l);
-            _connection.start();
-            _connection.setExceptionListener(this);
-            if (log.isInfoEnabled())
-                log.info(s_loc.get("jms-start-listener", _topicName));
-        }
-        catch (OpenJPAException ke) {
-            throw ke;
-        }
-        catch (Exception e) {
-            throw new UserException(s_loc.get("jms-provider-config",
-                _topicName, _tcfName), e).setFatal(true);
-        }
-    }
-
-    /**
-     * <p>Returns a {@link javax.jms.MessageListener} capable of
-     * understanding and processing messages created by
-     * {@link #createMessage}.</p>
-     * <p/>
-     * <p>The listener returned by this method is responsible for
-     * notifying the provider that a remote event has been received.</p>
+ MessageListener l = getMessageListener();
+ s.setMessageListener(l);
+ _connection.start();
+ _connection.setExceptionListener(this);
+ if (log.isInfoEnabled())
+ log.info(s_loc.get("jms-start-listener", _topicName));
+ }
+ catch (OpenJPAException ke) {
+ throw ke;
+ }
+ catch (Exception e) {
+ throw new UserException(s_loc.get("jms-provider-config",
+ _topicName, _tcfName), e).setFatal(true);
+ }
+ }
+
+    /* *
+     * Returns a {@link javax.jms.MessageListener} capable of
+     * understanding and processing messages created by {@link #createMessage}.
+     *  The listener returned by this method is responsible for
+     * notifying the provider that a remote event has been received.
      */
     protected MessageListener getMessageListener() {
         return new MessageListener() {

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LifecycleCallbacks.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LifecycleCallbacks.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LifecycleCallbacks.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LifecycleCallbacks.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LifecycleEvent.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LifecycleEvent.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LifecycleEvent.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LifecycleEvent.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -18,8 +18,8 @@
 import java.util.EventObject;
 
 /**
- * <p>Lifecycle event on a persistent instance.  The event source
- * is the persistent instance whose state has changed.</p>
+ * Lifecycle event on a persistent instance. The event source
+ * is the persistent instance whose state has changed.
  *
  * @author Steve Kim
  * @author Abe White
@@ -148,8 +148,8 @@
     /**
      * Constructor.
      *
-     * @param    pc        the persistent instance that triggered the event
-     * @param    type    the event type
+     * @param pc the persistent instance that triggered the event
+     * @param type the event type
      */
     public LifecycleEvent(Object pc, int type) {
         this(pc, null, type);
@@ -158,9 +158,9 @@
     /**
      * Constructor.
      *
-     * @param    pc        the persistent instance that triggered the event
-     * @param    type    the event type
-     * @param    related    the related instance such as the detached copy.
+     * @param pc the persistent instance that triggered the event
+     * @param type the event type
+     * @param related the related instance such as the detached copy.
      */
     public LifecycleEvent(Object pc, Object related, int type) {
         super(pc);
@@ -176,7 +176,7 @@
     }
 
     /**
-     *	Return the related object.
+     * Return the related object.
 	 */
 	public Object getRelated ()
 	{

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LifecycleEventManager.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LifecycleEventManager.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LifecycleEventManager.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LifecycleEventManager.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -27,15 +27,13 @@
 import org.apache.openjpa.meta.MetaDataDefaults;
 
 /**
- * <p>Manager that can be used to track and notify listeners on lifecycle
- * events.</p>
- * <p/>
- * <p>This class is optimized for event firing rather than for adding and
- * removing listeners, which are O(n) operations.  This class also does not
+ * Manager that can be used to track and notify listeners on lifecycle events.
+ *  This class is optimized for event firing rather than for adding and
+ * removing listeners, which are O(n) operations. This class also does not
  * maintain perfect set semantics for listeners; it is possible to wind up
  * having the same listener invoked multiple times for a single event if it
  * is added to this manager multiple times with different classes, or with
- * a base class and its subclass.</p>
+ * a base class and its subclass.
  *
  * @author Steve Kim
  * @author Abe White
@@ -47,7 +45,7 @@
 
     private static final Exception[] EMPTY_EXCEPTIONS = new Exception[0];
 
-    private Map _classListeners = null;    // class -> listener list
+    private Map _classListeners = null; // class -> listener list
     private ListenerList _listeners = null;
     private List _addListeners = new LinkedList();
     private List _remListeners = new LinkedList();
@@ -56,7 +54,7 @@
     private boolean _fail = false;
 
     /**
-     * Register a lifecycle listener for the given classes.  If the classes
+     * Register a lifecycle listener for the given classes. If the classes
      * array is null, register for all classes.
      */
     public synchronized void addListener(Object listener, Class[] classes) {
@@ -329,7 +327,7 @@
 
     /**
      * Fire an event with the given source and type to the given list of
-     * listeners.  The event may have already been constructed.
+     * listeners. The event may have already been constructed.
      */
     private Object fireEvent(LifecycleEvent ev, Object source, Object rel,
         int type, ListenerList listeners, boolean mock, boolean failFast,
@@ -497,8 +495,8 @@
     }
 
     /**
-     *	Extended list that tracks what event types its elements care about.
-     *	Maintains set semantics as well.
+     * Extended list that tracks what event types its elements care about.
+     * Maintains set semantics as well.
      */
     public static class ListenerList
         extends ArrayList {
@@ -538,7 +536,7 @@
         }
 
         /**
-         *	Return a mask of the event types the given listener processes.
+         * Return a mask of the event types the given listener processes.
          */
         private static int getEventTypes(Object listener) {
             int types = 0;

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LifecycleListener.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LifecycleListener.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LifecycleListener.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LifecycleListener.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -16,7 +16,7 @@
 package org.apache.openjpa.event;
 
 /**
- * <p>Interface for listening to all {@link LifecycleEvent}s.</p>
+ * Interface for listening to all {@link LifecycleEvent}s.
  *
  * @author Steve Kim
  * @author Abe White

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LoadListener.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LoadListener.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LoadListener.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LoadListener.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -16,7 +16,7 @@
 package org.apache.openjpa.event;
 
 /**
- * <p>Listener for when state is loaded into a persistent instnace.</p>
+ * Listener for when state is loaded into a persistent instnace.
  *
  * @author Steve Kim
  * @author Abe White

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LogOrphanedKeyAction.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LogOrphanedKeyAction.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LogOrphanedKeyAction.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/LogOrphanedKeyAction.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -23,7 +23,7 @@
 import org.apache.openjpa.meta.ValueMetaData;
 
 /**
- * <p>Log a message when an orphaned key is discovered.</p>
+ * Log a message when an orphaned key is discovered.
  *
  * @author Abe White
  * @since 3.2.2
@@ -38,35 +38,35 @@
     private short _level = Log.WARN;
 
     /**
-     * The channel to log to.  Defaults to <code>org.apache.openjpa.Runtime</code>.
+     * The channel to log to. Defaults to <code>org.apache.openjpa.Runtime</code>.
      */
     public String getChannel() {
         return _channel;
     }
 
     /**
-     * The channel to log to.  Defaults to <code>org.apache.openjpa.Runtime</code>.
+     * The channel to log to. Defaults to <code>org.apache.openjpa.Runtime</code>.
      */
     public void setChannel(String channel) {
         _channel = channel;
     }
 
     /**
-     * The level to log at.  Defaults to <code>WARN</code>.
+     * The level to log at. Defaults to <code>WARN</code>.
      */
     public short getLevel() {
         return _level;
     }
 
     /**
-     * The level to log at.  Defaults to <code>WARN</code>.
+     * The level to log at. Defaults to <code>WARN</code>.
      */
     public void setLevel(short level) {
         _level = level;
     }
 
     /**
-     * The level to log at.  Defaults to <code>WARN</code>.
+     * The level to log at. Defaults to <code>WARN</code>.
      */
     public void setLevel(String level) {
         _level = LogFactoryImpl.getLevel(level);

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/MethodLifecycleCallbacks.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/MethodLifecycleCallbacks.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/MethodLifecycleCallbacks.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/MethodLifecycleCallbacks.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -35,7 +35,7 @@
     private boolean _arg;
 
     /**
-     * Constructor.  Supply callback class and its callback method name.
+     * Constructor. Supply callback class and its callback method name.
      *
      * @arg Whether we expect a further argument such as in AfterDetach
      */
@@ -46,7 +46,7 @@
     }
 
     /**
-     * Constructor.  Supply callback method.
+     * Constructor. Supply callback method.
      */
     public MethodLifecycleCallbacks(Method method, boolean arg) {
         _callback = method;
@@ -87,8 +87,8 @@
     }
 
     /**
-     *	Helper method to return the named method of the given class, throwing
-     *	the proper exception on error.
+     * Helper method to return the named method of the given class, throwing
+     * the proper exception on error.
      */
     protected static Method getMethod(Class cls, String method, Class[] args) {
         try {

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/NoneOrphanedKeyAction.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/NoneOrphanedKeyAction.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/NoneOrphanedKeyAction.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/NoneOrphanedKeyAction.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -19,7 +19,7 @@
 import org.apache.openjpa.meta.ValueMetaData;
 
 /**
- * <p>Does nothing when an orphaned key is discovered.</p>
+ * Does nothing when an orphaned key is discovered.
  *
  * @author Abe White
  * @since 3.2.2

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/OrphanedKeyAction.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/OrphanedKeyAction.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/OrphanedKeyAction.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/OrphanedKeyAction.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -19,7 +19,7 @@
 import org.apache.openjpa.meta.ValueMetaData;
 
 /**
- * <p>Perform an action when OpenJPA detects an orphaned key in the database.</p>
+ * Perform an action when OpenJPA detects an orphaned key in the database.
  *
  * @author Abe White
  * @since 3.2.2
@@ -29,10 +29,10 @@
     /**
      * Callback received when OpenJPA discovers an orphaned key.
      *
-     * @param    oid        the orphaned key
-     * @param    sm        the instance representing the record in which the
+     * @param oid the orphaned key
+     * @param sm the instance representing the record in which the
      * key was discovered; may be null
-     * @param    vmd        the value in which the key was discovered
+     * @param vmd the value in which the key was discovered
      * @return the value to load into field <code>fmd</code>; typically
      * <code>null</code>
      */

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/PersistListener.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/PersistListener.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/PersistListener.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/PersistListener.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/RemoteCommitEvent.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/RemoteCommitEvent.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/RemoteCommitEvent.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/RemoteCommitEvent.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -26,9 +26,8 @@
 import org.apache.openjpa.util.UserException;
 
 /**
- * <p>Event type to hold the IDs of additions, updates, and
- * deletes.  This event type is also fully serializable for remote
- * communication.</p>
+ * Event type to hold the IDs of additions, updates, and
+ * deletes. This event type is also fully serializable for remote communication.
  *
  * @since 3.0
  * @author Patrick Linskey
@@ -68,15 +67,13 @@
     }
 
     /**
-     * Constructor.  All collections will be proxied with unmodifiable views.
+     * Constructor. All collections will be proxied with unmodifiable views.
      *
-     * @param    payloadType        PAYLOAD constant for type of data in this event
-     * @param    addIds            set of object IDs for added instances, or null
-     * @param    addClasses        set of class names for added instances
-     * @param    updates            set of class names or object IDs for updated
-     * instances
-     * @param    deletes            set of class names or object IDs for deleted
-     * instances
+     * @param payloadType PAYLOAD constant for type of data in this event
+     * @param addIds set of object IDs for added instances, or null
+     * @param addClasses set of class names for added instances
+     * @param updates set of class names or object IDs for updated instances
+     * @param deletes set of class names or object IDs for deleted instances
      */
     public RemoteCommitEvent(int payloadType, Collection addIds,
         Collection addClasses, Collection updates, Collection deletes) {

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/RemoteCommitEventManager.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/RemoteCommitEventManager.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/RemoteCommitEventManager.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/RemoteCommitEventManager.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -30,10 +30,10 @@
 import org.apache.openjpa.util.UserException;
 
 /**
- * <p>Manager that can be used to track and notify
+ * Manager that can be used to track and notify
  * {@link RemoteCommitListener}s on remote commit events. If remote events
  * are enabled, this manager should be installed as a transaction listener on
- * all brokers so that it knows when commits are made.</p>
+ * all brokers so that it knows when commits are made.
  *
  * @author Patrick Linskey
  * @author Abe White
@@ -50,7 +50,7 @@
     private boolean _transmitPersIds = false;
 
     /**
-     * Constructor.  Supply configuration.
+     * Constructor. Supply configuration.
      */
     public RemoteCommitEventManager(OpenJPAConfiguration conf) {
         _provider = conf.newRemoteCommitProviderInstance();

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/RemoteCommitListener.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/RemoteCommitListener.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/RemoteCommitListener.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/RemoteCommitListener.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -18,33 +18,25 @@
 import org.apache.openjpa.lib.util.Closeable;
 
 /**
- * <p>An entity that wishes to be notified when Brokers
- * associated with remote BrokerFactories commit.</p>
- * <p/>
- * <p>A RemoteCommitListener <b>is not</b> notified of commits that originated
+ * An entity that wishes to be notified when Brokers
+ * associated with remote BrokerFactories commit.
+ *  A RemoteCommitListener <b>is not</b> notified of commits that originated
  * with a Broker created from the BrokerFactory that it is
  * registered with. (Of course, if a listener is registered with multiple
- * factories, this situation might be complicated a bit.)</p>
- * <p/>
- * <p>Usage:
- * <code><pre>
- * 	import org.apache.openjpa.event.*;
- * 	import org.apache.openjpa.conf.*;
- * <p/>
- * 	{@link org.apache.openjpa.conf.OpenJPAConfiguration} conf = factory.getConfiguraiton ();
- * <p/>
- * 	RemoteCommitListener l = new RemoteCommitListener () {
- * 		public void afterCommit ({@link RemoteCommitEvent} e) {
- * 			// update a Swing widget when remote brokers make
- * 			// changes to reference data
- * 		}
- * <p/>
- * 		public void close () { }
- * 	};
- * <p/>
- * 	conf.getRemoteCommitEventManager ().addListener (l);
- * 	</pre></code>
- * </p>
+ * factories, this situation might be complicated a bit.)
+ *  Usage:
+ * <code><pre> import org.apache.openjpa.event.*;
+ * import org.apache.openjpa.conf.*;
+ * 
+ * {@link org.apache.openjpa.conf.OpenJPAConfiguration} conf = factory.getConfiguraiton ();
+ *  RemoteCommitListener l = new RemoteCommitListener () {
+ * public void afterCommit ({@link RemoteCommitEvent} e) {
+ * // update a Swing widget when remote brokers make
+ * // changes to reference data }
+ *  public void close () { } };
+ *  conf.getRemoteCommitEventManager ().addListener (l);
+ * </pre></code>
+ * 
  *
  * @author Patrick Linskey
  * @since 2.5.0

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/RemoteCommitProvider.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/RemoteCommitProvider.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/RemoteCommitProvider.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/RemoteCommitProvider.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -18,24 +18,20 @@
 import org.apache.openjpa.lib.util.Closeable;
 
 /**
- * <p>An entity that is responsible for communicating commit
+ * An entity that is responsible for communicating commit
  * notification to other {@link RemoteCommitEventManager}s. Each
  * event manager creates a remote commit provider, based on
  * the values of the <code>org.apache.openjpa.RemoteCommitProvider</code>
- * configuration property.</p>
- * <p/>
- * <p>An adapter that implements {@link TransactionListener} is
+ * configuration property.
+ *  An adapter that implements {@link TransactionListener} is
  * registered with each {@link org.apache.openjpa.kernel.Broker}. This adapter
  * invokes <code>broadcast</code>, which is responsible for
- * notifying other remote commit provider objects of the commit
- * changes.</p>
- * <p/>
- * <p>Upon receiving a notification from a different remote commit provider,
+ * notifying other remote commit provider objects of the commit changes.
+ *  Upon receiving a notification from a different remote commit provider,
  * a provider must notify all local remote commit listeners via the
- * {@link RemoteCommitEventManager#fireEvent} method.</p>
- * <p/>
- * <p>A remote commit provider <b>must not</b> fire remote events for
- * commits that originated with a local broker.</p>
+ * {@link RemoteCommitEventManager#fireEvent} method.
+ *  A remote commit provider <b>must not</b> fire remote events for
+ * commits that originated with a local broker.
  *
  * @author Patrick Linskey
  * @since 2.5.0
@@ -57,7 +53,7 @@
     public void broadcast(RemoteCommitEvent event);
 
     /**
-     *	Free the resources used by this provider.
+     * Free the resources used by this provider.
      */
     public void close();
 }

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/SingleJVMRemoteCommitProvider.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/SingleJVMRemoteCommitProvider.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/SingleJVMRemoteCommitProvider.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/SingleJVMRemoteCommitProvider.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -20,12 +20,12 @@
 import java.util.Set;
 
 /**
- * <p>Single-JVM-only implementation of {@link RemoteCommitProvider}
+ * Single-JVM-only implementation of {@link RemoteCommitProvider}
  * that listens for object modifications and propagates those changes
  * to other SingleJVMRemoteCommitProviders in the same JVM. This is
  * only useful for linking together multiple factories in the same
  * JVM that are all loaded in the same classloader, which is a rare
- * circumstance.</p>
+ * circumstance.
  *
  * @author Patrick Linskey
  * @since 2.5.0

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/StoreListener.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/StoreListener.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/StoreListener.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/StoreListener.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -16,7 +16,7 @@
 package org.apache.openjpa.event;
 
 /**
- * <p>Listener for when persistent instances are stored to the database.</p>
+ * Listener for when persistent instances are stored to the database.
  *
  * @author Steve Kim
  * @author Abe White

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/TCPRemoteCommitProvider.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/TCPRemoteCommitProvider.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/TCPRemoteCommitProvider.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/TCPRemoteCommitProvider.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -460,8 +460,7 @@
     }
 
     /**
-     * Responsible for listening for incoming packets and processing
-     * them.
+     * Responsible for listening for incoming packets and processing them.
      */
     private static class TCPPortListener
         implements Runnable {
@@ -487,14 +486,12 @@
         private int _port;
 
         /**
-         * Should be set to <code>true</code> once the listener is
-         * listening.
+         * Should be set to <code>true</code> once the listener is listening.
          */
         private boolean _isRunning = false;
 
         /**
-         * Construct a new TCPPortListener configured to use the
-         * specified port.
+         * Construct a new TCPPortListener configured to use the specified port.
          */
         private TCPPortListener(int port, Log log)
             throws UnknownHostException, IOException {
@@ -745,20 +742,19 @@
     }
 
     /**
-     *	Utility class to store an InetAddress and an int. Not using
-     *	InetSocketAddress because it's a JDK1.4 API. This also
-     *	provides a wrapper around the socket(s) associated with this
-     *	address.
+     * Utility class to store an InetAddress and an int. Not using
+     * InetSocketAddress because it's a JDK1.4 API. This also
+     * provides a wrapper around the socket(s) associated with this address.
      */
     private class HostAddress {
 
         private InetAddress _address;
         private int _port;
-        private long _timeLastError;        // millis
-        private boolean _isAvailable;        // is peer thought to be up
-        private int _infosIssued = 0;    // limit log entries
+        private long _timeLastError; // millis
+        private boolean _isAvailable; // is peer thought to be up
+        private int _infosIssued = 0; // limit log entries
 
-        private GenericObjectPool _socketPool;    // reusable open sockets
+        private GenericObjectPool _socketPool; // reusable open sockets
 
         /**
          * Construct a new host address from a string of the form
@@ -892,7 +888,7 @@
         }
 
         /**
-         *	Factory for pooled sockets.
+         * Factory for pooled sockets.
          */
         private class SocketPoolableObjectFactory
             implements PoolableObjectFactory {
@@ -929,7 +925,6 @@
             public void activateObject (Object value)
 			{
 			}
-
 
 			public void passivateObject (Object value)
 			{

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/TransactionEvent.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/TransactionEvent.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/TransactionEvent.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/TransactionEvent.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -22,8 +22,8 @@
 import org.apache.openjpa.kernel.Broker;
 
 /**
- * <p>A transactional event.  The event source is the {@link Broker} whose
- * transaction state changed.</p>
+ * A transactional event. The event source is the {@link Broker} whose
+ * transaction state changed.
  *
  * @since 3.0
  * @author Abe White
@@ -38,8 +38,7 @@
 
     /**
      * Event type signifying that changes are about to be flushed to the
-     * datastore.  This does not necessarily mean that a commit is taking
-     * place.
+     * datastore. This does not necessarily mean that a commit is taking place.
      */
     public static final int BEFORE_FLUSH = 1;
 
@@ -93,12 +92,12 @@
     /**
      * Constructor.
      *
-     * @param    pm            the event source
-     * @param    type        the event type
-     * @param    objs        transactional objects
-     * @param    addClss        classes of added instances
-     * @param    updateClss    classes of updated instances
-     * @param    deleteClss    classes of deleted instances
+     * @param pm the event source
+     * @param type the event type
+     * @param objs transactional objects
+     * @param addClss classes of added instances
+     * @param updateClss classes of updated instances
+     * @param deleteClss classes of deleted instances
      */
     public TransactionEvent(Broker broker, int type,
         Collection objs, Collection addClss, Collection updateClss,
@@ -120,7 +119,7 @@
 
     /**
      * Return the unmodifiable set of persistence capable objects
-     * participating in the transaction.  This set will contain all dirty
+     * participating in the transaction. This set will contain all dirty
      * objects, but may not contain clean objects.
      */
     public Collection getTransactionalObjects() {
@@ -129,8 +128,7 @@
 
     /**
      * Return the unmodifiable the set of classes of
-     * persistence capable objects that were created in
-     * the transaction.
+     * persistence capable objects that were created in the transaction.
      */
     public Collection getPersistedTypes() {
         return _addClss;
@@ -138,17 +136,15 @@
 
     /**
      * Return the unmodifiable the set of classes of
-     * persistence capable objects that were modified in
-     * the transaction.
+     * persistence capable objects that were modified in the transaction.
      */
     public Collection getUpdatedTypes() {
         return _updateClss;
     }
 
     /**
-     *	Return the unmodifiable the set of classes of
-     *  persistence capable objects that were deleted in
-     *  the transaction.
+     * Return the unmodifiable the set of classes of
+     * persistence capable objects that were deleted in the transaction.
      */
     public Collection getDeletedTypes ()
 	{

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/TransactionEventManager.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/TransactionEventManager.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/TransactionEventManager.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/TransactionEventManager.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -18,8 +18,8 @@
 import org.apache.openjpa.lib.util.concurrent.AbstractConcurrentEventManager;
 
 /**
- * <p>Manager that can be used to track and notify transaction listeners
- * of transaction-related events.</p>
+ * Manager that can be used to track and notify transaction listeners
+ * of transaction-related events.
  *
  * @author Patrick Linskey
  * @author Abe White
@@ -78,7 +78,7 @@
     }
 
     /**
-     *	Fire the given event to all registered listeners.
+     * Fire the given event to all registered listeners.
      */
     protected void fireEvent(Object event, Object listener) {
         TransactionEvent ev = (TransactionEvent) event;

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/TransactionListener.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/TransactionListener.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/TransactionListener.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/event/TransactionListener.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -16,7 +16,7 @@
 package org.apache.openjpa.event;
 
 /**
- * <p>Interface for listening to all {@link TransactionEvent}s.
+ * Interface for listening to all {@link TransactionEvent}s.
  *
  * @author Patrick Linskey
  * @author Abe White

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractBrokerFactory.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractBrokerFactory.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractBrokerFactory.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractBrokerFactory.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -45,8 +45,8 @@
 import org.apache.openjpa.util.UserException;
 
 /**
- * <p>Abstract implementation of the {@link BrokerFactory}
- * that must be subclassed for a specific runtime.</p>
+ * Abstract implementation of the {@link BrokerFactory}
+ * that must be subclassed for a specific runtime.
  *
  * @author Abe White
  */
@@ -106,7 +106,7 @@
     }
 
     /**
-     * Constructor.  Configuration must be provided on construction.
+     * Constructor. Configuration must be provided on construction.
      */
     protected AbstractBrokerFactory(OpenJPAConfiguration config) {
         _conf = config;
@@ -206,7 +206,7 @@
     }
 
     /**
-     * Load the configured persistent classes list.  Performed automatically
+     * Load the configured persistent classes list. Performed automatically
      * whenever a broker is created.
      */
     private void loadPersistentTypes(ClassLoader envLoader) {
@@ -360,7 +360,7 @@
     }
 
     /**
-     * Replaces the factory with this JVMs pooled version if it exists.  Also
+     * Replaces the factory with this JVMs pooled version if it exists. Also
      * freezes the factory.
      */
     protected Object readResolve()
@@ -382,16 +382,16 @@
     ////////////////////////
 
     /**
-     * Return a new StoreManager for this runtime.  Note that the instance
+     * Return a new StoreManager for this runtime. Note that the instance
      * returned here may be wrapped before being passed to the
      * {@link #newBroker} method.
      */
     protected abstract StoreManager newStoreManager();
 
     /**
-     * Find a pooled broker, or return null if none.  If using
+     * Find a pooled broker, or return null if none. If using
      * managed transactions, looks for a transactional broker;
-     * otherwise returns null by default.  This method will be called before
+     * otherwise returns null by default. This method will be called before
      * {@link #newStoreManager} so that factory subclasses implementing
      * pooling can return a matching manager before a new {@link StoreManager}
      * is created.
@@ -418,7 +418,7 @@
 
     /**
      * Setup transient state used by this factory based on the
-     * current configuration, which will subsequently be locked down.  This
+     * current configuration, which will subsequently be locked down. This
      * method will be called before the first broker is requested,
      * and will be re-called each time the factory is deserialized into a JVM
      * that has no configuration for this data store.
@@ -563,7 +563,7 @@
     ////////////////////
 
     /**
-     * Throws a {@link UserException} if a transaction is active.  The thrown
+     * Throws a {@link UserException} if a transaction is active. The thrown
      * exception will contain all the Brokers with active transactions as
      * failed objects in the nested exceptions.
      */
@@ -641,8 +641,8 @@
     }
 
     /**
-     *	Simple synchronization listener to remove completed transactions
-     *	from our cache.
+     * Simple synchronization listener to remove completed transactions
+     * from our cache.
      */
     private class RemoveTransactionSync
         implements Synchronization {

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractFieldManager.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractFieldManager.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractFieldManager.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractFieldManager.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -19,8 +19,8 @@
 import org.apache.openjpa.util.InternalException;
 
 /**
- * <p>Abstract {@link FieldManager} for easy subclassing.  Throws exceptions
- * for all methods.</p>
+ * Abstract {@link FieldManager} for easy subclassing. Throws exceptions
+ * for all methods.
  *
  * @author Abe White
  */

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractLockManager.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractLockManager.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractLockManager.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractLockManager.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -71,7 +71,7 @@
     }
 
     /**
-     *	Does nothing by default.
+     * Does nothing by default.
      */
     public void close ()
 	{

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractPCData.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractPCData.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractPCData.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractPCData.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -35,7 +35,7 @@
 import org.apache.openjpa.util.Proxy;
 
 /**
- * <p>Abstract base class which implements core PCData behavior.</p>
+ * Abstract base class which implements core PCData behavior.
  *
  * @author Patrick Linskey
  * @author Abe White
@@ -111,7 +111,7 @@
     }
 
     /**
-     * Transform the given data value to its field value.  The data value
+     * Transform the given data value to its field value. The data value
      * may be a key, value, or element of a map or collection.
      */
     protected Object toNestedField(OpenJPAStateManager sm, ValueMetaData vmd,
@@ -142,7 +142,7 @@
     }
 
     /**
-     * Transform the given data into a relation field value.  Default
+     * Transform the given data into a relation field value. Default
      * implementation assumes the data is an oid.
      */
     protected Object toRelationField(OpenJPAStateManager sm, ValueMetaData vmd,
@@ -151,7 +151,7 @@
     }
 
     /**
-     * Transform the given data into an embedded PC field value.  Default
+     * Transform the given data into an embedded PC field value. Default
      * implementation assumes the data is an {@link AbstractPCData}.
      */
     protected Object toEmbeddedField(OpenJPAStateManager sm, ValueMetaData vmd,
@@ -165,7 +165,7 @@
     }
 
     /**
-     * Transform the given field value to a data value for caching.  Return
+     * Transform the given field value to a data value for caching. Return
      * {@link #NULL} if unable to cache.
      */
     protected Object toData(FieldMetaData fmd, Object val, StoreContext ctx) {
@@ -237,7 +237,7 @@
     }
 
     /**
-     * Transform the given nested value to a cachable value.  Return
+     * Transform the given nested value to a cachable value. Return
      * {@link #NULL} if the value cannot be cached.
      */
     protected Object toNestedData(ValueMetaData vmd, Object val,
@@ -270,7 +270,7 @@
     }
 
     /**
-     * Return the value to cache for the given object.  Caches its oid by
+     * Return the value to cache for the given object. Caches its oid by
      * default.
      */
     protected Object toRelationData(Object val, StoreContext ctx) {
@@ -278,7 +278,7 @@
     }
 
     /**
-     * Return the value to cache for the given embedded PC.  Caches a
+     * Return the value to cache for the given embedded PC. Caches a
      * {@link PCData} from {@link #newEmbeddedPCData} by default.
      */
     protected Object toEmbeddedData(Object val, StoreContext ctx) {
@@ -299,7 +299,7 @@
     }
 
     /**
-     *	Tracks proxy data along with list elements.
+     * Tracks proxy data along with list elements.
      */
     private static class ProxyDataList
         extends ArrayList {

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractPCResultObjectProvider.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractPCResultObjectProvider.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractPCResultObjectProvider.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractPCResultObjectProvider.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -22,10 +22,9 @@
 import org.apache.openjpa.util.StoreException;
 
 /**
- * <p>Abstract implementation of {@link PCResultObjectProvider}
+ * Abstract implementation of {@link PCResultObjectProvider}
  * that implements {@link ResultObjectProvider#getResultObject}
- * by assembling the necessary information about the object to be
- * loaded.</p>
+ * by assembling the necessary information about the object to be loaded.
  *
  * @author Patrick Linskey
  */
@@ -91,23 +90,23 @@
 
     /**
      * Load data from the current input record into the given state
-     * manager.  Remember to call {@link OpenJPAStateManager#setVersion} to set
+     * manager. Remember to call {@link OpenJPAStateManager#setVersion} to set
      * the optimistic versioning information, if it has any.
      */
     protected abstract void load(OpenJPAStateManager sm, FetchState fetch)
         throws Exception;
 
     /**
-     * Override if desired.  Does nothing by default.
+     * Override if desired. Does nothing by default.
      */
     public void open()
         throws Exception {
     }
 
     /**
-     * Override if desired.  Returns false by default.
+     * Override if desired. Returns false by default.
      *
-     * @see    ResultObjectProvider#supportsRandomAccess
+     * @see ResultObjectProvider#supportsRandomAccess
      */
     public boolean supportsRandomAccess() {
         return false;
@@ -116,15 +115,15 @@
     /**
      * Implement this method to advance the input.
      *
-     * @see    ResultObjectProvider#next
+     * @see ResultObjectProvider#next
      */
     public abstract boolean next()
         throws Exception;
 
     /**
-     * Override if desired.  Throws an exception by default.
+     * Override if desired. Throws an exception by default.
      *
-     * @see    ResultObjectProvider#absolute
+     * @see ResultObjectProvider#absolute
      */
     public boolean absolute(int pos)
         throws Exception {
@@ -132,9 +131,9 @@
     }
 
     /**
-     * Override if desired.  Returns {@link Integer#MAX_VALUE} by default.
+     * Override if desired. Returns {@link Integer#MAX_VALUE} by default.
      *
-     * @see    ResultObjectProvider#size
+     * @see ResultObjectProvider#size
      */
     public int size()
         throws Exception {
@@ -142,9 +141,9 @@
     }
 
     /**
-     * Override if desired.  Throws an exception by default.
+     * Override if desired. Throws an exception by default.
      *
-     * @see    ResultObjectProvider#reset
+     * @see ResultObjectProvider#reset
      */
     public void reset()
         throws Exception {
@@ -152,16 +151,16 @@
     }
 
     /**
-     * Override if desired.  Does nothing by default.
+     * Override if desired. Does nothing by default.
      *
-     * @see    ResultObjectProvider#close
+     * @see ResultObjectProvider#close
      */
     public void close()
         throws Exception {
     }
 
     /**
-     *	Throws a {@link StoreException} by default.
+     * Throws a {@link StoreException} by default.
      */
     public void handleCheckedException(Exception e) {
         throw new StoreException (e);

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractStoreQuery.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractStoreQuery.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractStoreQuery.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AbstractStoreQuery.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -25,7 +25,7 @@
 import org.apache.openjpa.util.InternalException;
 
 /**
- * <p>Abstract {@link StoreQuery} that implements most methods as no-ops.</p>
+ * Abstract {@link StoreQuery} that implements most methods as no-ops.
  *
  * @author Abe White
  * @since 4.0

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AttachManager.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AttachManager.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AttachManager.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AttachManager.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -59,7 +59,7 @@
     private AttachStrategy _detach = null;
 
     /**
-     * Constructor.  Supply broker attaching to.
+     * Constructor. Supply broker attaching to.
      */
     public AttachManager(BrokerImpl broker, boolean copyNew, OpCallbacks call) {
         _broker = broker;
@@ -98,7 +98,7 @@
         }
         catch (CallbackException ce) {
             excep = ce;
-            return null;    // won't be reached as the exceps will be rethrown
+            return null; // won't be reached as the exceps will be rethrown
         }
         finally {
             List exceps = null;
@@ -213,10 +213,10 @@
     /**
      * Attach.
      *
-     * @param    toAttach    the detached object
-     * @param    into        the instance we're attaching into
-     * @param    owner        state manager for <code>into</code>
-     * @param    ownerMeta    the field we traversed to find <code>toAttach</code>
+     * @param toAttach the detached object
+     * @param into the instance we're attaching into
+     * @param owner state manager for <code>into</code>
+     * @param ownerMeta the field we traversed to find <code>toAttach</code>
      */
     Object attach(Object toAttach, PersistenceCapable into,
         OpenJPAStateManager owner, ValueMetaData ownerMeta) {
@@ -322,8 +322,8 @@
     }
 
     /**
-     *	Throw an exception if the given object is not managed; otherwise
-     *	return its state manager.
+     * Throw an exception if the given object is not managed; otherwise
+     * return its state manager.
      */
     StateManagerImpl assertManaged(Object obj) {
         StateManagerImpl sm = _broker.getStateManagerImpl(obj, true);

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AttachStrategy.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AttachStrategy.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AttachStrategy.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AttachStrategy.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -49,12 +49,12 @@
     /**
      * Attach.
      *
-     * @param    manager        manager holding cache of attached instances
-     * @param    toAttach    detached instance
-     * @param    meta        metadata for the instance being attached
-     * @param    into        instance we're attaching into
-     * @param    owner        state manager for <code>into</code>
-     * @param    ownerMeta    field we traversed to find <code>toAttach</code>
+     * @param manager manager holding cache of attached instances
+     * @param toAttach detached instance
+     * @param meta metadata for the instance being attached
+     * @param into instance we're attaching into
+     * @param owner state manager for <code>into</code>
+     * @param ownerMeta field we traversed to find <code>toAttach</code>
      */
     public abstract Object attach(AttachManager manager,
         Object toAttach, ClassMetaData meta, PersistenceCapable into,
@@ -92,12 +92,11 @@
     /**
      * Attach the given field into the given instance.
      *
-     * @param    toAttach the detached persistent instance
-     * @param    sm            state manager for the managed instance we're copying
-     * into; <code>toAttach</code> also uses this state
-     * manager
-     * @param    fmd            metadata on the field we're copying
-     * @param    nullLoaded    if false, nulls will be considered unloaded and will
+     * @param toAttach the detached persistent instance
+     * @param sm state manager for the managed instance we're copying
+     * into; <code>toAttach</code> also uses this state manager
+     * @param fmd metadata on the field we're copying
+     * @param nullLoaded if false, nulls will be considered unloaded and will
      * not be attached
      */
     protected boolean attachField(AttachManager manager, Object toAttach,
@@ -275,7 +274,7 @@
 
     /**
      * Replace the contents of <code>toc</code> with the contents of
-     * <code>frmc</code>.  Neither collection is null.
+     * <code>frmc</code>. Neither collection is null.
      */
     private void replaceCollection(AttachManager manager, Collection frmc,
         Collection toc, OpenJPAStateManager sm, FieldMetaData fmd) {
@@ -341,7 +340,7 @@
     /**
      * Returns an attached version of the <code>frml</code>
      * list if it is different than <code>tol</code>. If the lists
-     * will be identical, returns <code>tol</code>.  Neither list is null.
+     * will be identical, returns <code>tol</code>. Neither list is null.
      */
     private Collection replaceList(AttachManager manager, Collection frml,
         Collection tol, OpenJPAStateManager sm, FieldMetaData fmd) {
@@ -372,7 +371,7 @@
 
     /**
      * Replace the contents of <code>tom</code> with the contents of
-     * <code>frmm</code>.  Neither map is null.
+     * <code>frmm</code>. Neither map is null.
      */
     private void replaceMap(AttachManager manager, Map frmm, Map tom,
         OpenJPAStateManager sm, FieldMetaData fmd) {
@@ -489,8 +488,8 @@
     }
 
     /**
-     *	Return true if the given objects are equal.  PCs are compared for
-     *	on JVM identity.
+     * Return true if the given objects are equal. PCs are compared for
+     * on JVM identity.
      */
     private static boolean equals(Object a, Object b, boolean pc) {
         if (a == b)

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AutoClear.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AutoClear.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AutoClear.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AutoClear.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -16,7 +16,7 @@
 package org.apache.openjpa.kernel;
 
 /**
- * <p>State clearing constants.</p>
+ * State clearing constants.
  *
  * @author Abe White
  * @since 4.0

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AutoDetach.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AutoDetach.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AutoDetach.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/AutoDetach.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -31,8 +31,8 @@
     public static final int DETACH_COMMIT = 2 << 1;
 
     /**
-     *	Detach context on any nontransctional read, such that each
-     *	nontransactional operation uses a new persistence context in essence.
+     * Detach context on any nontransctional read, such that each
+     * nontransactional operation uses a new persistence context in essence.
      */
     public static final int DETACH_NONTXREAD = 2 << 2;
 }

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/Bootstrap.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/Bootstrap.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/Bootstrap.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/Bootstrap.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -29,7 +29,7 @@
 import org.apache.openjpa.util.UserException;
 
 /**
- * <p>Helper methods for acquiring {@link BrokerFactory} objects</p>
+ * Helper methods for acquiring {@link BrokerFactory} objects
  *
  * @since 4.0.0
  */
@@ -48,8 +48,8 @@
     }
 
     /**
-     * Return a new factory for the given configuration.  The classloader
-     * will be used to load the factory class.  If no classloader is given,
+     * Return a new factory for the given configuration. The classloader
+     * will be used to load the factory class. If no classloader is given,
      * the thread's context classloader is used.
      */
     public static BrokerFactory newBrokerFactory(ConfigurationProvider conf,
@@ -84,8 +84,8 @@
     }
 
     /**
-     * Return a pooled factory for the given configuration.  The classloader
-     * will be used to load the factory class.  If no classloader is given,
+     * Return a pooled factory for the given configuration. The classloader
+     * will be used to load the factory class. If no classloader is given,
      * the thread's context classloader is used.
      */
     public static BrokerFactory getBrokerFactory(ConfigurationProvider conf,
@@ -113,7 +113,7 @@
     }
 
     /**
-     *	Instantiate the factory class designated in properties.
+     * Instantiate the factory class designated in properties.
      */
     private static Class getFactoryClass(ConfigurationProvider conf,
         ClassLoader loader) {

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/Broker.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/Broker.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/Broker.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/Broker.java Thu Jul 13 16:44:20 2006
@@ -5,7 +5,7 @@
  * 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
+ * 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,
@@ -29,9 +29,9 @@
 import org.apache.openjpa.util.RuntimeExceptionTranslator;
 
 /**
- * <p>The broker is the primary interface into the OpenJPA runtime.  Each broker
+ * The broker is the primary interface into the OpenJPA runtime. Each broker
  * maintains an independent object cache and an independent transactional
- * context.</p>
+ * context.
  *
  * @since 4.0
  * @author Abe White
@@ -45,7 +45,7 @@
     /**
      * Set the broker's behavior for implicit actions such as flushing,
      * automatic detachment, and exceptions thrown by managed instances outside
-     * a broker operation.  A broker's implicit behavior can only be set once;
+     * a broker operation. A broker's implicit behavior can only be set once;
      * after the first invocation with non-null arguments,
      * subsequent invocations of this method are ignored.
      */
@@ -160,13 +160,13 @@
 
     /**
      * Whether to check for a global transaction upon every managed,
-     * non-transactional operation.  Defaults to false.
+     * non-transactional operation. Defaults to false.
      */
     public boolean getSyncWithManagedTransactions();
 
     /**
      * Whether to check for a global transaction upon every managed,
-     * non-transactional operation.  Defaults to false.
+     * non-transactional operation. Defaults to false.
      */
     public void setSyncWithManagedTransactions(boolean resync);
 
@@ -212,7 +212,7 @@
     public void setEvictFromDataCache(boolean evict);
 
     /**
-     * Put the specified key-value pair into the map of user objects.  Use
+     * Put the specified key-value pair into the map of user objects. Use
      * a value of null to remove the key.
      *
      * @since 3.2
@@ -242,7 +242,7 @@
 
     /**
      * Register a listener for lifecycle-related events on the specified
-     * classes.  If the classes are null, all events will be propagated to
+     * classes. If the classes are null, all events will be propagated to
      * the listener.
      *
      * @since 3.3
@@ -284,30 +284,24 @@
 
     /**
      * Issue a commit and then start a new transaction. This is identical to:
-     * <pre>
-     * 	broker.commit ();
-     * 	broker.begin ();
-     * 	</pre>
-     * except that the broker's internal atomic lock is utilized,
+     * <pre> broker.commit (); broker.begin ();
+     * </pre> except that the broker's internal atomic lock is utilized,
      * so this method can be safely executed from multiple threads.
      *
-     * @see    #commit()
-     * @see    #begin()
+     * @see #commit()
+     * @see #begin()
      * @since 2.4
      */
     public void commitAndResume();
 
     /**
      * Issue a rollback and then start a new transaction. This is identical to:
-     * <pre>
-     * 	broker.rollback ();
-     * 	broker.begin ();
-     * 	</pre>
-     * except that the broker's internal atomic lock is utilized,
+     * <pre> broker.rollback (); broker.begin ();
+     * </pre> except that the broker's internal atomic lock is utilized,
      * so this method can be safely executed from multiple threads.
      *
-     * @see    #rollback()
-     * @see    #begin()
+     * @see #rollback()
+     * @see #begin()
      * @since 2.4
      */
     public void rollbackAndResume();
@@ -353,7 +347,7 @@
     public void releaseSavepoint(String name);
 
     /**
-     * Flush all transactional instances to the data store.  This method may
+     * Flush all transactional instances to the data store. This method may
      * set the rollback only flag on the current transaction if it encounters
      * an error.
      *
@@ -373,9 +367,9 @@
 
     /**
      * Validate the changes made in this transaction, reporting any optimistic
-     * violations, constraint violations, etc.  In a datastore transaction or
+     * violations, constraint violations, etc. In a datastore transaction or
      * a flushed optimistic transaction, this method will act just like
-     * {@link #flush}.  In an optimistic transaction that has not yet begun a
+     * {@link #flush}. In an optimistic transaction that has not yet begun a
      * datastore-level transaction, however, it will only report exceptions
      * that would occur on flush, without retaining any datastore resources.
      */
@@ -392,12 +386,12 @@
     public void persistAll(Collection objs, OpCallbacks call);
 
     /**
-     * Make the given instance persistent.  Unlike other persist operations,
+     * Make the given instance persistent. Unlike other persist operations,
      * this method does <b>not</b> immediately cascade to fields marked
      * {@link ValueMetaData#CASCADE_IMMEDIATE}.
      *
-     * @param    pc    the instance to persist
-     * @param    id    the id to give the state manager; may be null for default
+     * @param pc the instance to persist
+     * @param id the id to give the state manager; may be null for default
      * @return the state manager for the newly persistent instance
      */
     public OpenJPAStateManager persist(Object pc, Object id, OpCallbacks call);
@@ -413,13 +407,13 @@
     public void deleteAll(Collection objs, OpCallbacks call);
 
     /**
-     * Release the given object from management.  This operation is not
+     * Release the given object from management. This operation is not
      * recursive.
      */
     public void release(Object pc, OpCallbacks call);
 
     /**
-     * Release the given objects from management.  This operation is not
+     * Release the given objects from management. This operation is not
      * recursive.
      */
     public void releaseAll(Collection objs, OpCallbacks call);
@@ -489,7 +483,7 @@
      *
      * @param pc instance to import
      * @return the re-attached instance
-     * @param    copyNew    whether to copy new instances
+     * @param copyNew whether to copy new instances
      */
     public Object attach(Object pc, boolean copyNew, OpCallbacks call);
 
@@ -501,7 +495,7 @@
      *
      * @param objs array of instances to import
      * @return the re-attached instances
-     * @param    copyNew    whether to copy new instances
+     * @param copyNew whether to copy new instances
      */
     public Object[] attachAll(Collection objs, boolean copyNew,
         OpCallbacks call);
@@ -554,9 +548,9 @@
     /**
      * Ensure that the given instance is locked at the given lock level.
      *
-     * @param    pc        the object to lock
-     * @param    level    the lock level to use
-     * @param    timeout    the number of milliseconds to wait for the lock before
+     * @param pc the object to lock
+     * @param level the lock level to use
+     * @param timeout the number of milliseconds to wait for the lock before
      * giving up, or -1 for no limit
      * @since 3.1
      */
@@ -573,9 +567,9 @@
     /**
      * Ensure that the given instances are locked at the given lock level.
      *
-     * @param    objs    the objects to lock
-     * @param    level    the lock level to use
-     * @param    timeout    the number of milliseconds to wait for the lock before
+     * @param objs the objects to lock
+     * @param level the lock level to use
+     * @param timeout the number of milliseconds to wait for the lock before
      * giving up, or -1 for no limit
      * @since 3.1
      */
@@ -591,7 +585,7 @@
     public void lockAll(Collection objs, OpCallbacks call);
 
     /**
-     * Cancel all pending data store statements.  If statements are cancelled
+     * Cancel all pending data store statements. If statements are cancelled
      * while a flush is in progress, the transaction rollback only flag will
      * be set.
      *
@@ -608,23 +602,21 @@
     public void dirtyType(Class cls);
 
     /**
-     * Begin a logical operation.  This indicates to the broker the
+     * Begin a logical operation. This indicates to the broker the
      * granularity of an operation which may require pre/post operation
      * side-effects, such as non-tx detach.
      * Will lock the broker until the {@link #endOperation} is called.
      *
      * @param syncTrans whether instances may be loaded/modified during
      * this operation requiring a re-check of global tx
-     * @return whether this is the outermost operation on the
-     * stack
+     * @return whether this is the outermost operation on the stack
      */
     public boolean beginOperation(boolean syncTrans);
 
     /**
-     * End a logical operation.  This indicates to the broker the
+     * End a logical operation. This indicates to the broker the
      * granularity of an operation which may require pre/post operation
-     * side-effects, such as non-tx detach.
-     * Unlocks the given broker.
+     * side-effects, such as non-tx detach. Unlocks the given broker.
      *
      * @return whether this is the outermost operation on the stack
      */
@@ -651,15 +643,14 @@
     public void assertActiveTransaction();
 
     /**
-     *	Throw an exception if there is no transaction active and
-     *	nontransactional reading is not enabled.
+     * Throw an exception if there is no transaction active and
+     * nontransactional reading is not enabled.
 	 */
 	public void assertNontransactionalRead ();
 
-
 	/**
-	 *	Throw an exception if a write operation is not permitted (there is
-	 *	no active transaction and nontransactional writing is not enabled).
+	 * Throw an exception if a write operation is not permitted (there is
+	 * no active transaction and nontransactional writing is not enabled).
 	 */
 	public void assertWriteOperation ();
 }