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 [7/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/kernel/StateManagerImpl.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/StateManagerImpl.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/StateManagerImpl.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/StateManagerImpl.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,
@@ -55,17 +55,16 @@
 import serp.util.Numbers;
 
 /**
- * <p>Implementation of the {@link OpenJPAStateManager} interface for use
- * with this runtime.  Each state manager manages the state of a single
- * persistence capable instance.  The state manager is also responsible for
- * all communications about the instance to the {@link StoreManager}.</p>
- * <p/>
- * <p>The state manager uses the State pattern in both its interaction with
+ * Implementation of the {@link OpenJPAStateManager} interface for use
+ * with this runtime. Each state manager manages the state of a single
+ * persistence capable instance. The state manager is also responsible for
+ * all communications about the instance to the {@link StoreManager}.
+ *  The state manager uses the State pattern in both its interaction with
  * the governed instance and its interaction with the broker.
  * In its interactions with the persistence capable instance, it uses the
- * {@link FieldManager} interface.  Similarly, when interacting with the
+ * {@link FieldManager} interface. Similarly, when interacting with the
  * broker, it uses the {@link PCState} singleton that represents
- * the current lifecycle state of the instance.</p>
+ * the current lifecycle state of the instance.
  *
  * @author Abe White
  */
@@ -178,10 +177,10 @@
     }
 
     /**
-     * Set or reset the lifecycle state of the managed instance.  If the
+     * Set or reset the lifecycle state of the managed instance. If the
      * transactional state of the instance changes, it will be enlisted/
-     * delisted from the current transaction as necessary.  The given
-     * state will be initialized after being set.  If the given state
+     * delisted from the current transaction as necessary. The given
+     * state will be initialized after being set. If the given state
      * is the same as the current state, this method will have no effect.
      */
     private void setPCState(PCState state) {
@@ -320,7 +319,7 @@
 
     /**
      * Load the state of this instance based on the given fetch configuration
-     * and load mode.  Return true if any data was loaded, false otherwise.
+     * and load mode. Return true if any data was loaded, false otherwise.
      */
     protected boolean load(FetchState fetchState, int loadMode,
         BitSet exclude, Object sdata, boolean forWrite) {
@@ -419,7 +418,7 @@
                     load = fetchState == null ||
                         fetchState.requiresLoad(this, fmds[i]);
                     break;
-                default:     // LOAD_ALL
+                default: // LOAD_ALL
                     load = true;
             }
 
@@ -492,7 +491,7 @@
      * Make sure we were assigned an oid, and perform actions to make it
      * permanent.
      *
-     * @param    recache        whether to recache ourself on the new oid
+     * @param recache whether to recache ourself on the new oid
      */
     private void assertObjectIdAssigned(boolean recache) {
         if (!isNew() || isDeleted() || (_flags & FLAG_OID_ASSIGNED) > 0)
@@ -828,7 +827,7 @@
     /**
      * Notification that the object is about to be accessed.
      *
-     * @param    field    the field number being read, or -1 if not a single
+     * @param field the field number being read, or -1 if not a single
      * field read
      */
     void beforeRead(int field) {
@@ -852,7 +851,7 @@
     /**
      * Delegates to the current state.
      *
-     * @see    PCState#beforeFlush
+     * @see PCState#beforeFlush
      */
     void beforeFlush(int reason, OpCallbacks call) {
         _state.beforeFlush(this, reason == BrokerImpl.FLUSH_LOGICAL, call);
@@ -861,7 +860,7 @@
     /**
      * Delegates to the current state.
      *
-     * @see    PCState#flush
+     * @see PCState#flush
      */
     void afterFlush(int reason) {
         // nothing happens when we flush non-persistent states
@@ -903,8 +902,8 @@
      * Delegates to the current state after checking the value
      * of the RetainState flag.
      *
-     * @see    PCState#commit
-     * @see    PCState#commitRetain
+     * @see PCState#commit
+     * @see PCState#commitRetain
      */
     void commit() {
         // release locks before oid updated
@@ -933,8 +932,8 @@
      * Delegates to the current state after checking the value
      * of the RetainState flag.
      *
-     * @see    PCState#rollback
-     * @see    PCState#rollbackRestore
+     * @see PCState#rollback
+     * @see PCState#rollbackRestore
      */
     void rollback() {
         // release locks
@@ -969,8 +968,8 @@
     /**
      * Delegates to the current state.
      *
-     * @see    PCState#persist
-     * @see    Broker#persist
+     * @see PCState#persist
+     * @see Broker#persist
      */
     void persist() {
         setPCState(_state.persist(this));
@@ -979,8 +978,8 @@
     /**
      * Delegates to the current state.
      *
-     * @see    PCState#delete
-     * @see    Broker#delete
+     * @see PCState#delete
+     * @see Broker#delete
      */
     void delete() {
         setPCState(_state.delete(this));
@@ -989,8 +988,8 @@
     /**
      * Delegates to the current state.
      *
-     * @see    PCState#nontransactional
-     * @see    Broker#nontransactional
+     * @see PCState#nontransactional
+     * @see Broker#nontransactional
      */
     void nontransactional() {
         setPCState(_state.nontransactional(this));
@@ -999,8 +998,8 @@
     /**
      * Delegates to the current state.
      *
-     * @see    PCState#transactional
-     * @see    Broker#transactional
+     * @see PCState#transactional
+     * @see Broker#transactional
      */
     void transactional() {
         setPCState(_state.transactional(this));
@@ -1009,8 +1008,8 @@
     /**
      * Delegates to the current state.
      *
-     * @see    PCState#release
-     * @see    Broker#release
+     * @see PCState#release
+     * @see Broker#release
      */
     void release(boolean unproxy) {
         release(unproxy, false);
@@ -1035,8 +1034,8 @@
     /**
      * Delegates to the current state.
      *
-     * @see    PCState#evict
-     * @see    Broker#evict
+     * @see PCState#evict
+     * @see Broker#evict
      */
     void evict() {
         setPCState(_state.evict(this));
@@ -1101,7 +1100,7 @@
     }
 
     /**
-     * Perform state transitions after refresh.  This method is only
+     * Perform state transitions after refresh. This method is only
      * called if {@link #beforeRefresh} returns true.
      */
     void afterRefresh() {
@@ -1140,7 +1139,7 @@
     ///////////
 
     /**
-     * Notification that we've been read-locked.  Pass in the level at which
+     * Notification that we've been read-locked. Pass in the level at which
      * we were locked and the level at which we should write lock ourselves
      * on dirty.
      */
@@ -1370,9 +1369,9 @@
     /**
      * Make the given field dirty.
      *
-     * @param    mutate    if null, may be an SCO mutation; if true, is certainly
+     * @param mutate if null, may be an SCO mutation; if true, is certainly
      * a mutation (or at least treat as one)
-     * @return        {@link Boolean#FALSE} if this instance was already dirty,
+     * @return {@link Boolean#FALSE} if this instance was already dirty,
      * <code>null</code> if it was dirty but not since flush, and
      * {@link Boolean#TRUE} if it was not dirty
      */
@@ -1412,13 +1411,13 @@
                             (fmd.isEmbedded()) ? Boolean.TRUE : Boolean.FALSE;
                         break;
                     default:
-                        mutate = Boolean.FALSE;        // not sco
+                        mutate = Boolean.FALSE; // not sco
                 }
             }
 
             // possibly change state
             boolean active = _broker.isActive();
-            clean = !_state.isDirty();     // intentional direct access
+            clean = !_state.isDirty(); // intentional direct access
 
             // fire event fast before state change.
             if (clean)
@@ -1490,7 +1489,7 @@
     /**
      * Fire post-dirty events after field value changes.
      *
-     * @param    status    return value from {@link #dirty(int,boolean,boolean)}
+     * @param status return value from {@link #dirty(int,boolean,boolean)}
      */
     private void postDirty(Boolean status) {
         if (Boolean.TRUE.equals(status))
@@ -2499,7 +2498,7 @@
 
     /**
      * Executes pre-clear callbacks, clears all managed fields, and calls the
-     * {@link #setLoaded} method with a value of false.  Primary key fields
+     * {@link #setLoaded} method with a value of false. Primary key fields
      * are not cleared.
      */
     void clearFields() {
@@ -2551,7 +2550,7 @@
 
     /**
      * If the field isn't already saved, saves the currently loaded field
-     * state of the instance.  The saved values can all be restored via
+     * state of the instance. The saved values can all be restored via
      * {@link #restoreFields}.
      */
     private void saveField(int field) {
@@ -2673,8 +2672,8 @@
     }
 
     /**
-     * Get ready for a flush.  Persists all persistence-capable object fields,
-     * and checks for illegal null values.  Also assigns oids and field values
+     * Get ready for a flush. Persists all persistence-capable object fields,
+     * and checks for illegal null values. Also assigns oids and field values
      * for all strategies that don't require flushing.
      */
     void preFlush(boolean logical, OpCallbacks call) {
@@ -2905,7 +2904,7 @@
      * might exclude some fields which are then immediately loaded in a
      * separate step before being returned to the user.
      *
-     * @param    field    the field index that was loaded, or -1 to indicate
+     * @param field the field index that was loaded, or -1 to indicate
      * that a group of possibly unknown fields was loaded
      */
     private void postLoad(int field, FetchState fetchState) {
@@ -2965,8 +2964,7 @@
     }
 
     /**
-     * Set whether this instance requires a version check on the
-     * next flush.
+     * Set whether this instance requires a version check on the next flush.
      */
     void setCheckVersion(boolean versionCheck) {
         if (versionCheck)
@@ -2983,8 +2981,7 @@
     }
 
     /**
-     * Set whether this instance requires a version update on the
-     * next flush.
+     * Set whether this instance requires a version update on the next flush.
      */
     void setUpdateVersion(boolean versionUpdate) {
         if (versionUpdate)
@@ -3015,7 +3012,7 @@
     }
 
     /**
-     *	Unlock the state manager.
+     * Unlock the state manager.
      */
 	protected void unlock ()
 	{

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/StoreContext.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/StoreContext.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/StoreContext.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/StoreContext.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>Represents a set of managed objects and their environment.</p>
+ * Represents a set of managed objects and their environment.
  *
  * @since 4.0
  * @author Abe White
@@ -42,7 +42,7 @@
     public static final int OID_ALLOW_NEW = 2 << 3;
 
     /**
-     * Return the broker for this context, if possible.  Note that a broker
+     * Return the broker for this context, if possible. Note that a broker
      * will be unavailable in remote contexts, and this method may throw
      * an exception to that effect.
      */
@@ -71,7 +71,7 @@
     public LockManager getLockManager();
 
     /**
-     * Return the store manager in use.  This will be a wrapper around the
+     * Return the store manager in use. This will be a wrapper around the
      * native store manager, which you can retrieve via
      * {@link DelegatingStoreManager#getInnermostDelegate}.
      */
@@ -91,21 +91,21 @@
      * Return the cached instance for the given oid/object, or null if not
      * cached.
      *
-     * @param    oid        the object's id
+     * @param oid the object's id
      * @return the cached object, or null if not cached
      */
     public Object findCached(Object oid, FindCallbacks call);
 
     /**
-     * Find the persistence object with the given oid.  If
+     * Find the persistence object with the given oid. If
      * <code>validate</code> is true, the broker will check the store
-     * for the object, and return null if it does not exist.  If
-     * <code>validate</code> is false, this method never returns null.  The
+     * for the object, and return null if it does not exist. If
+     * <code>validate</code> is false, this method never returns null. The
      * broker will either return its cached instance, attempt to create a
      * hollow instance, or throw an <code>ObjectNotFoundException</code> if
      * unable to return a hollow instance.
      *
-     * @param    validate    if true, validate that the instance exists in the
+     * @param validate if true, validate that the instance exists in the
      * store and load fetch group fields, otherwise return
      * any cached or hollow instance
      */
@@ -114,25 +114,25 @@
     /**
      * Return the objects with the given oids.
      *
-     * @param    oids        the oids of the objects to return
+     * @param oids the oids of the objects to return
      * @return the objects that were looked up, in the same order as the oids
      * parameter
-     * @see    #find(Object,boolean)
+     * @see #find(Object,boolean)
      */
     public Object[] findAll(Collection oids, boolean validate,
         FindCallbacks call);
 
     /**
-     * Return the object with the given oid.  If present, the
-     * cached instance will be returned.  Otherwise, the instance will be
+     * Return the object with the given oid. If present, the
+     * cached instance will be returned. Otherwise, the instance will be
      * initialized through the store as usual; however, in this case
      * the store will be passed the given execution data, and the
      * system will load the object according to the given fetch configuratiion
      * (or the context's configuration, if the given one is null).
      * Fields can optionally be excluded from required loading using the
-     * <code>exclude</code> mask.  By default this method does not find new
+     * <code>exclude</code> mask. By default this method does not find new
      * unflushed instances, validates, and does not throw an exception
-     * if a cached instance has been deleted concurrently.  These options
+     * if a cached instance has been deleted concurrently. These options
      * are controllable through the given <code>OID_XXX</code> flags.
      */
     public Object find(Object oid, FetchState fetchState, BitSet exclude,
@@ -141,13 +141,13 @@
     /**
      * Return the objects with the given oids.
      *
-     * @see    #find(Object,FetchState,BitSet,Object,int)
+     * @see #find(Object,FetchState,BitSet,Object,int)
      */
     public Object[] findAll(Collection oids, FetchState fetchState,
         BitSet exclude, Object edata, int flags);
 
     /**
-     * Return an iterator over all instances of the given type.  The iterator
+     * Return an iterator over all instances of the given type. The iterator
      * should be closed with {@link ImplHelper#close} when no longer needed.
      * This method delegates to {@link StoreManager#executeExtent}.
      */
@@ -155,36 +155,35 @@
         FetchConfiguration fetch, boolean ignoreChanges);
 
     /**
-     * Immediately load the given object's persistent fields.  One might
+     * Immediately load the given object's persistent fields. One might
      * use this action to make sure that an instance's fields are loaded
-     * before transitioning it to transient.  Note that this action is not
-     * recursive.  Any related objects that are loaded will not necessarily
-     * have their fields loaded.  Unmanaged target is ignored.
+     * before transitioning it to transient. Note that this action is not
+     * recursive. Any related objects that are loaded will not necessarily
+     * have their fields loaded. Unmanaged target is ignored.
      *
-     * @param    fgOnly        indicator as to whether to retrieve only fields
+     * @param fgOnly indicator as to whether to retrieve only fields
      * in the current fetch groups, or all fields
-     * @see    #retrieve
+     * @see #retrieve
      */
     public void retrieve(Object pc, boolean fgOnly, OpCallbacks call);
 
     /**
-     * Retrieve the given objects' persistent state.  Unmanaged targets are
+     * Retrieve the given objects' persistent state. Unmanaged targets are
      * ignored.
      *
-     * @param    fgOnly        indicator as to whether to retrieve only fields
-     * @see    #retrieve
+     * @param fgOnly indicator as to whether to retrieve only fields
+     * @see #retrieve
      */
     public void retrieveAll(Collection objs, boolean fgOnly, OpCallbacks call);
 
     /**
      * Make the given instance embedded.
      *
-     * @param    obj            the instance to embed; may be null to create a
-     * new instance
-     * @param    id            the id to give the embedded state manager; may be
+     * @param obj the instance to embed; may be null to create a new instance
+     * @param id the id to give the embedded state manager; may be
      * null for default
-     * @param    owner        the owning state manager
-     * @param    ownerMeta    the value in which the object is embedded
+     * @param owner the owning state manager
+     * @param ownerMeta the value in which the object is embedded
      * @return the state manager for the embedded instance
      */
     public OpenJPAStateManager embed(Object obj, Object id,
@@ -252,13 +251,13 @@
 
     /**
      * Whether to maintain the order in which objects are dirtied for
-     * {@link #getDirtyObjects}.  Default is the store manager's decision.
+     * {@link #getDirtyObjects}. Default is the store manager's decision.
      */
     public boolean getOrderDirtyObjects();
 
     /**
      * Whether to maintain the order in which objects are dirtied for
-     * {@link #getDirtyObjects}.  Default is the store manager's decision.
+     * {@link #getDirtyObjects}. Default is the store manager's decision.
      */
     public void setOrderDirtyObjects(boolean order);
 
@@ -342,13 +341,13 @@
 
     /**
      * Detach mode constant to determine which fields are part of the
-     * detached graph.  Defaults to {@link DetachState#DETACH_LOADED}.
+     * detached graph. Defaults to {@link DetachState#DETACH_LOADED}.
      */
     public int getDetachState();
 
     /**
      * Detach mode constant to determine which fields are part of the
-     * detached graph.  Defaults to {@link DetachState#DETACH_LOADED}.
+     * detached graph. Defaults to {@link DetachState#DETACH_LOADED}.
      */
     public void setDetachState(int mode);
 
@@ -379,7 +378,7 @@
     /**
      * If a large number of objects will be created, modified, or deleted
      * during this transaction setting this option to true will reduce memory
-     * usage if you perform periodic flushes.  Upon transaction commit the
+     * usage if you perform periodic flushes. Upon transaction commit the
      * data cache will have to more aggressively flush objects. The store cache
      * will have to flush instances of objects for each class of object
      * modified during the transaction. A side benefit of large transaction
@@ -417,21 +416,19 @@
     public boolean hasConnection();
 
     /**
-     * Return the connection in use by the context, or a new connection if
-     * none.
+     * Return the connection in use by the context, or a new connection if none.
      */
     public Object getConnection();
 
     /**
-     *	Synchronizes on an internal lock if the
-     *	<code>Multithreaded</code> flag is set to true.  Make sure to call
-	 *	{@link #unlock} in a finally clause of the same method.
+     * Synchronizes on an internal lock if the
+     * <code>Multithreaded</code> flag is set to true. Make sure to call
+	 * {@link #unlock} in a finally clause of the same method.
 	 */
 	public void lock ();
 
-
 	/**
-	 *	Releases the internal lock.
+	 * Releases the internal lock.
 	 */
 	public void unlock ();
 }

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/StoreManager.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/StoreManager.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/StoreManager.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/StoreManager.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,8 +25,8 @@
 import org.apache.openjpa.meta.ValueStrategies;
 
 /**
- * <p>Interface to be implemented by data store mechanisms to interact with
- * this runtime.</p>
+ * Interface to be implemented by data store mechanisms to interact with
+ * this runtime.
  *
  * @author Abe White
  */
@@ -44,15 +44,15 @@
     public static final int FORCE_LOAD_ALL = 2;
 
     /**
-     * Set a reference to the corresponding context.  This method
-     * will be called before the store manager is used.  The store manager
+     * Set a reference to the corresponding context. This method
+     * will be called before the store manager is used. The store manager
      * is responsible for pulling any necessary configuration data from the
      * context, including the transaction mode and connection retain mode.
      */
     public void setContext(StoreContext ctx);
 
     /**
-     * Notification that an optimistic transaction has started.  This method
+     * Notification that an optimistic transaction has started. This method
      * does not replace the {@link #begin} method, which will still be called
      * when a true data store transaction should begin.
      */
@@ -67,10 +67,10 @@
     /**
      * Begin a data store transaction. After this method is called,
      * it is assumed that all further operations are operating in a single
-     * transaction that can be committed or rolled back.  If optimistic
+     * transaction that can be committed or rolled back. If optimistic
      * transactions are in use, this method will only be called when the
      * system requires a transactionally consistent connection due to a
-     * user request to flush or commit the transaction.  In this case, it
+     * user request to flush or commit the transaction. In this case, it
      * is possible that the optimistic transaction does not have the latest
      * versions of all instances (i.e. another transaction has modified the
      * same instances and committed since the optimistic transaction started).
@@ -101,8 +101,8 @@
      * Update the version information in the given state manager to the
      * version stored in the data store.
      *
-     * @param    sm                the instance to check
-     * @param    edata            the current execution data, or null if not
+     * @param sm the instance to check
+     * @param edata the current execution data, or null if not
      * given to the calling method of the context
      * @return true if the instance still exists in the
      * datastore and is up-to-date, false otherwise
@@ -110,28 +110,27 @@
     public boolean syncVersion(OpenJPAStateManager sm, Object edata);
 
     /**
-     * Initialize the given state manager.  The object id of the
+     * Initialize the given state manager. The object id of the
      * state manager will be set, and the state manager's metadata be set to
      * the class of the instance to load, or possibly one of its superclasses.
      * Initialization involves first calling the
      * {@link OpenJPAStateManager#initialize} method with
      * a new instance of the correct type constructed with the
-     * {@link org.apache.openjpa.enhance.PCRegistry#newInstance(Class, 
+     * {@link org.apache.openjpa.enhance.PCRegistry#newInstance(Class,
      * org.apache.openjpa.enhance.StateManager, boolean)} method
      * (this will reset the state manager's metadata if the actual type was a
-     * subclass).  After instance initialization, load any the fields for the
+     * subclass). After instance initialization, load any the fields for the
      * given fetch configuration that can be efficiently retrieved. If any of
      * the configured fields are not loaded in this method, they will be
-     * loaded with a subsequent call to {@link #load}.  If this method is
+     * loaded with a subsequent call to {@link #load}. If this method is
      * called during a data store transaction, the instance's database record
-     * should be locked.  Version information can be loaded if desired through
+     * should be locked. Version information can be loaded if desired through
      * the {@link OpenJPAStateManager#setVersion} method.
      *
-     * @param    sm        the instance to initialize
-     * @param    state    the lifecycle state to initialize the state
-     * manager with
-     * @param    fetchState    configuration for how to load the instance
-     * @param    edata    the current execution data, or null if not
+     * @param sm the instance to initialize
+     * @param state the lifecycle state to initialize the state manager with
+     * @param fetchState configuration for how to load the instance
+     * @param edata the current execution data, or null if not
      * given to the calling method of the broker
      * @return true if the matching instance exists in the data
      * store, false otherwise
@@ -144,22 +143,22 @@
      * Note that any collection or map types loaded into the state manager
      * will be proxied with the correct type; therefore the stroe manager
      * does not have to load the same concrete collection/map types as the
-     * instance declares.  However, array types must be consistent with the
-     * array type stored by the persistence capable instance.  If this method
+     * instance declares. However, array types must be consistent with the
+     * array type stored by the persistence capable instance. If this method
      * is called during a data store transaction, the instance should be
-     * locked.  If the given state manager does not have its version set
+     * locked. If the given state manager does not have its version set
      * already, version information can be loaded if desired through the
      * {@link OpenJPAStateManager#setVersion} method.
      *
-     * @param    sm            the instance to load
-     * @param    fields        set of fields to load; all field indexes in this
+     * @param sm the instance to load
+     * @param fields set of fields to load; all field indexes in this
      * set must be loaded; this set is mutable
-     * @param    fetchState        the fetch configuration to use when loading
+     * @param fetchState the fetch configuration to use when loading
      * related objects
-     * @param    lockLevel    attempt to load simple fields at this lock level;
+     * @param lockLevel attempt to load simple fields at this lock level;
      * relations should be loaded at the read lock level
      * of the fetch configuration
-     * @param    edata        the current execution data, or null if not
+     * @param edata the current execution data, or null if not
      * given to the calling method of the broker
      * @return false if the object no longer exists in the
      * database, true otherwise
@@ -169,55 +168,53 @@
 
     /**
      * Initialize, load, or validate the existance of all of the given
-     * objects.  This method is called from various broker methods that act
-     * on multiple objects, such as {@link StoreContext#retrieveAll}.  It gives
+     * objects. This method is called from various broker methods that act
+     * on multiple objects, such as {@link StoreContext#retrieveAll}. It gives
      * the store manager an opportunity to efficiently batch-load data for
-     * several objects.  Each of the given state managers will be in one of
+     * several objects. Each of the given state managers will be in one of
      * three states, each requiring a different action:
      * <ul>
      * <li><code>stateManager.getManagedInstance () == null</code>: An
-     * uninitialized state manager.  Perform the same actions as in
-     * {@link #initialize}.</p>
+     * uninitialized state manager. Perform the same actions as in
+     * {@link #initialize}.
      * <li><code>load != FORCE_LOAD_NONE || stateManager.getPCState ()
      * == PCState.HOLLOW</code>: A hollow state manager, or one whose
      * fields must be loaded because this is a refresh or retrieve action.
      * Peform the same actions as in {@link #load}, choosing the fields
      * to load based on the fetch configuration, or loading all fields
-     * if <code>load == FORCE_LOAD_ALL</code>.  Any required fields left
+     * if <code>load == FORCE_LOAD_ALL</code>. Any required fields left
      * unloaded will cause a subsequent invocation of {@link #load} on
      * the individual object in question.</li>
      * <li><code>load == FORCE_LOAD_NONE &amp;&amp;
      * stateManager.getPCState () != PCState.HOLLOW</code>: A non-hollow
-     * state manager.  Perform the same actions as in {@link #exists},
-     * and load additional state if desired.  Non-hollow objects will only
+     * state manager. Perform the same actions as in {@link #exists},
+     * and load additional state if desired. Non-hollow objects will only
      * be included outside of refresh invocations if a user calls
      * <code>findAll</code> with the <code>validate</code>
      * parameter set to <code>true</code>.</li>
-     * </ul>
-     * Store managers that cannot efficiently batch load can simply test
+     * </ul> Store managers that cannot efficiently batch load can simply test
      * for these conditions and delegate to the proper methods.
      *
-     * @param    sms        the state manager instances to load
-     * @param    state    the lifecycle state to initialize uninitialized
+     * @param sms the state manager instances to load
+     * @param state the lifecycle state to initialize uninitialized
      * state managers with; may be null if no uninitialized
      * instances are included in <code>sms</code>
-     * @param    load    one of the FORCE_LOAD_* constants describing the
-     * fields to force-load if this is a refresh or
-     * retrieve action
-     * @param    fetchState    the current fetch configuration to use when loading
+     * @param load one of the FORCE_LOAD_* constants describing the
+     * fields to force-load if this is a refresh or retrieve action
+     * @param fetchState the current fetch configuration to use when loading
      * related objects
-     * @param    edata    the current execution data, or null if not
+     * @param edata the current execution data, or null if not
      * given to the calling method of the broker
      * @return a collection of the state manager identities for
      * which no data store record exists
-     * @see    org.apache.openjpa.util.ImplHelper#loadAll
+     * @see org.apache.openjpa.util.ImplHelper#loadAll
      */
     public Collection loadAll(Collection sms, PCState state, int load,
         FetchState fetchState, Object edata);
 
     /**
      * Notification that the given state manager is about to change its
-     * lifecycle state.  The store manager is not required to do anything in
+     * lifecycle state. The store manager is not required to do anything in
      * this method, but some back ends may need to.
      *
      * @since 3.0
@@ -232,52 +229,50 @@
      * store action, such as persistent-clean instances or persistent-dirty
      * instances that have not been modified since they were last flushed.
      * For datastore updates and inserts, the dirty, non-flushed fields of
-     * each state should be flushed.  New instances without an assigned object
-     * id should be given one via {@link OpenJPAStateManager#setObjectId}.  New
+     * each state should be flushed. New instances without an assigned object
+     * id should be given one via {@link OpenJPAStateManager#setObjectId}. New
      * instances with value-strategy fields that have not been assigned yet
-     * should have their fields set.  Datastore version information should be
+     * should have their fields set. Datastore version information should be
      * updated during flush, and the state manager's version indicator
      * updated through the {@link OpenJPAStateManager#setNextVersion} method.
      * The current version will roll over to this next version upon successful
      * commit.
      *
-     * @see    org.apache.openjpa.util.ApplicationIds#assign()
+     * @see org.apache.openjpa.util.ApplicationIds#assign()
      */
     public Collection flush(Collection sms);
 
     /**
-     * Assign an object id to the given new instance.  Return false if the
+     * Assign an object id to the given new instance. Return false if the
      * instance cannot be assigned an identity because a flush is required
      * (for example, the identity is determined by the datastore on insert).
      * For application identity instances, the assigned object id should be
-     * based on field state.  The implementation is responsible for using the
-     * proper value strategy according to the instance metadata.  This method
+     * based on field state. The implementation is responsible for using the
+     * proper value strategy according to the instance metadata. This method
      * is called the first time a user requests the oid of a new instance
      * before flush.
      *
-     * @param    preFlush    whether this assignment is being requested by the
+     * @param preFlush whether this assignment is being requested by the
      * system as part of pre-flush activities, and can
-     * be ignored if it is more efficient to assign within
-     * {@link #flush}
-     * @see    org.apache.openjpa.util.ImplHelper#generateFieldValue
-     * @see    org.apache.openjpa.util.ImplHelper#generateIdentityValue
-     * @see    org.apache.openjpa.util.ApplicationIds#assign()
+     * be ignored if it is more efficient to assign within {@link #flush}
+     * @see org.apache.openjpa.util.ImplHelper#generateFieldValue
+     * @see org.apache.openjpa.util.ImplHelper#generateIdentityValue
+     * @see org.apache.openjpa.util.ApplicationIds#assign()
      * @since 3.3
      */
     public boolean assignObjectId(OpenJPAStateManager sm, boolean preFlush);
 
     /**
-     * Assign a value to the given field.  Return false if the value cannot
+     * Assign a value to the given field. Return false if the value cannot
      * be assigned because a flush is required (for example, the field value
-     * is determined by the datastore on insert).  This method is called the
+     * is determined by the datastore on insert). This method is called the
      * first time a user requests the value of a field with a value-strategy
      * on a new instance before flush.
      *
-     * @param    preFlush    whether this assignment is being requested by the
+     * @param preFlush whether this assignment is being requested by the
      * system as part of pre-flush activities, and can
-     * be ignored if it is more efficient to assign within
-     * {@link #flush}
-     * @see    org.apache.openjpa.util.ImplHelper#generateFieldValue
+     * be ignored if it is more efficient to assign within {@link #flush}
+     * @see org.apache.openjpa.util.ImplHelper#generateFieldValue
      * @since 4.0
      */
     public boolean assignField(OpenJPAStateManager sm, int field,
@@ -293,14 +288,14 @@
 
     /**
      * Return the class used by this StoreManager for datastore identity
-     * values.  The given metadata may be null, in which case the return
+     * values. The given metadata may be null, in which case the return
      * value should the common datastore identity class for all classes, or
      * null if this store manager does not use a common identity class.
      */
     public Class getDataStoreIdType(ClassMetaData meta);
 
     /**
-     * Copy the given object id value.  Use the described type of the given
+     * Copy the given object id value. Use the described type of the given
      * metadata, which may be a subclass of the given oid's described type.
      */
     public Object copyDataStoreId(Object oid, ClassMetaData meta);
@@ -312,22 +307,22 @@
     public Object newDataStoreId(Object oidVal, ClassMetaData meta);
 
     /**
-     * Return a connection to the data store suitable for client use.  If
+     * Return a connection to the data store suitable for client use. If
      * this method is called during a data store transaction, thie connection
-     * must be transactional.  If no connection is in use, this method should
+     * must be transactional. If no connection is in use, this method should
      * create one to return.
      */
     public Object getClientConnection();
 
     /**
-     * Instruct the store to retain a connection for continued use.  This
+     * Instruct the store to retain a connection for continued use. This
      * will be invoked automatically based on the user's configured connection
      * retain mode.
      */
     public void retainConnection();
 
     /**
-     * Instruct the store to release a retained connection.  This
+     * Instruct the store to release a retained connection. This
      * will be invoked automatically based on the user's configured connection
      * retain mode.
      */
@@ -343,26 +338,26 @@
 
     /**
      * Return a provider for all instances of the given candidate class,
-     * optionally including subclasses.  The given candidate may be an
-     * unmapped type with mapped subclasses.  If the provider is iterated
+     * optionally including subclasses. The given candidate may be an
+     * unmapped type with mapped subclasses. If the provider is iterated
      * within a data store transaction, returned instances should be locked.
      */
     public ResultObjectProvider executeExtent(ClassMetaData meta,
         boolean subclasses, FetchConfiguration fetch);
 
     /**
-     * Return a query implementation suitable for this store.  If the query
+     * Return a query implementation suitable for this store. If the query
      * is iterated within a data store transaction, returned instances should
-     * be locked.  Return null if this store does not support native execution
-     * of the given language.  OpenJPA can execute JPQL in memory even without 
+     * be locked. Return null if this store does not support native execution
+     * of the given language. OpenJPA can execute JPQL in memory even without
      * back end support.
      *
-     * @param    language the query language
+     * @param language the query language
      */
     public StoreQuery newQuery(String language);
 
     /**
-     * Return a fetch configuration suitable for this runtime.  Typically
+     * Return a fetch configuration suitable for this runtime. Typically
      * will be or extend <code>org.apache.openjpa.kernel.FetchConfigurationImpl</code>.
      */
     public FetchConfiguration newFetchConfiguration();
@@ -374,22 +369,22 @@
      * @param v1 the first version object to compare
      * @param v2 the second version object to compare
      * @return <ul>
-     *         <li>{@link #VERSION_LATER} if <code>v1</code>
-     *         is later than <code>v2</code></li>
-     *         <li>{@link #VERSION_EARLIER} if <code>v1</code>
-     *         is earlier than <code>v2</code></li>
-     *         <li>{@link #VERSION_SAME} if <code>v1</code>
-     *         is the same as <code>v2</code></li>
-     *         <li>{@link #VERSION_DIFFERENT} if <code>v1</code>
-     *         is different from <code>v2</code>, but the time
-     *         difference of the versions cannot be determined</li>
-     *         </ul>
+     * <li>{@link #VERSION_LATER} if <code>v1</code>
+     * is later than <code>v2</code></li>
+     * <li>{@link #VERSION_EARLIER} if <code>v1</code>
+     * is earlier than <code>v2</code></li>
+     * <li>{@link #VERSION_SAME} if <code>v1</code>
+     * is the same as <code>v2</code></li>
+     * <li>{@link #VERSION_DIFFERENT} if <code>v1</code>
+     * is different from <code>v2</code>, but the time
+     * difference of the versions cannot be determined</li>
+     * </ul>
      */
     public int compareVersion(OpenJPAStateManager state, Object v1, Object v2);
 
     /**
      * Return a sequence that generates datastore identity values for the
-     * given class.  This method will only be called when the identity strategy
+     * given class. This method will only be called when the identity strategy
      * for the class is one of:
      * <ul>
      * <li>{@link ValueStrategies#NATIVE}</li>
@@ -404,15 +399,14 @@
     public Seq getDataStoreIdSequence(ClassMetaData forClass);
 
     /**
-     * Return a sequence that generates values for the given field.  This
+     * Return a sequence that generates values for the given field. This
      * method will only be called when the value strategy for the field
      * is one of:
      * <ul>
      * <li>{@link ValueStrategies#NATIVE}</li>
      * <li>{@link ValueStrategies#AUTOASSIGN}</li>
      * <li>{@link ValueStrategies#INCREMENT}</li>
-     * </ul>
-     * If the value strategy cannot be represented as a sequence, return
+     * </ul> If the value strategy cannot be represented as a sequence, return
      * null.
      *
      * @since 4.0
@@ -420,9 +414,9 @@
     public Seq getValueSequence(FieldMetaData forField);
 
     /**
-     *	Free any resources this store manager is using.
+     * Free any resources this store manager is using.
 	 *
-	 *	@since	2.5
+	 * @since	2.5
 	 */
 	public void close ();
 }

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/StoreQuery.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/StoreQuery.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/StoreQuery.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/StoreQuery.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,
@@ -28,9 +28,9 @@
 import org.apache.openjpa.meta.FieldMetaData;
 
 /**
- * <p>Component that executes queries against the datastore.  For
+ * Component that executes queries against the datastore. For
  * expression-based queries, consider subclassing
- * {@link ExpressionStoreManagerQuery}.</p>
+ * {@link ExpressionStoreManagerQuery}.
  *
  * @author Abe White
  * @since 4.0
@@ -52,13 +52,13 @@
     public QueryContext getContext();
 
     /**
-     * Set the current query context.  This will be called before use.
+     * Set the current query context. This will be called before use.
      */
     public void setContext(QueryContext ctx);
 
     /**
      * This is invoked when the user or a facade creates a new query with
-     * an object that the system does not recognize.  Return true if
+     * an object that the system does not recognize. Return true if
      * the object is recognized by the store, false otherwise.
      */
     public boolean setQuery(Object query);
@@ -74,13 +74,12 @@
     public AggregateListener getAggregateListener(String tag);
 
     /**
-     * Create a new key for caching compiled query information.  May be
-     * null.
+     * Create a new key for caching compiled query information. May be null.
      */
     public Object newCompilationKey();
 
     /**
-     * Create a new compilation for this query.  May be null.
+     * Create a new compilation for this query. May be null.
      */
     public Object newCompilation();
 
@@ -108,36 +107,36 @@
 
     /**
      * Return an executor for in-memory execution of this query.
-     * Executors must be cachable and thread safe.  If this class returns
+     * Executors must be cachable and thread safe. If this class returns
      * true from {@link #supportsAbstractExecutors}, the given metadata
      * will always be for the candidate class of this query, or possibly
      * null if the candidate class is not itself persistence capable (like
-     * an interface or abstract base class).  Otherwise, the given type will
+     * an interface or abstract base class). Otherwise, the given type will
      * be a mapped class.
      *
-     * @param    subs    whether to include dependent mapped subclasses in the
+     * @param subs whether to include dependent mapped subclasses in the
      * results; independent subclasses should never be included
      */
     public Executor newInMemoryExecutor(ClassMetaData meta, boolean subs);
 
     /**
      * Return an executor for datastore execution of this query.
-     * Executors must be cachable and thread safe.  If this class returns
+     * Executors must be cachable and thread safe. If this class returns
      * true from {@link #supportsAbstractExecutors}, the given metadata
      * will always be for the candidate class of this query, or possibly
      * null if the candidate class is not itself persistence capable (like
-     * an interface or abstract base class).  Otherwise, the given type will
+     * an interface or abstract base class). Otherwise, the given type will
      * be a mapped class.
      *
-     * @param    subs    whether to include dependent mapped subclasses in the
+     * @param subs whether to include dependent mapped subclasses in the
      * results; independent subclasses should never be included
      */
     public Executor newDataStoreExecutor(ClassMetaData meta, boolean subs);
 
     /**
      * Return true if this query supports execution against abstract or
-     * interface types.  Returns false by default, meaning we will only
-     * request executors for persistent classes.  In this case, we will
+     * interface types. Returns false by default, meaning we will only
+     * request executors for persistent classes. In this case, we will
      * automatically combine the results of the executors for all
      * implementing classes if we execute a query for an interface for
      * abstract type.
@@ -160,32 +159,32 @@
     public boolean supportsParameterDeclarations();
 
     /**
-     *  An executor provides a uniform interface to the mechanism for executing
-     *	either an in-memory or datastore query.  In the common case, the
-     *	{@link #executeQuery} method will be called before other methods,
-     *	though this is not guaranteed.
+     * An executor provides a uniform interface to the mechanism for executing
+     * either an in-memory or datastore query. In the common case, the
+     * {@link #executeQuery} method will be called before other methods,
+     * though this is not guaranteed.
      *
-     *  @author Marc Prud'hommeaux
+     * @author Marc Prud'hommeaux
      */
     public static interface Executor {
 
         /**
          * Return the result of executing this query with the given parameter
-         * values.  If this query is a projection and this executor does not
+         * values. If this query is a projection and this executor does not
          * pack results itself, each element of the returned result object
          * provider should be an object array containing the projection values.
          *
-         * @param    lrs        true if the query result should be treated as a
+         * @param lrs true if the query result should be treated as a
          * large result set, assuming the query is not an
          * aggregate and does not have grouping
-         * @see    #isPacking
+         * @see #isPacking
          */
         public ResultObjectProvider executeQuery(StoreQuery q,
             Object[] params, boolean lrs, long startIdx, long endIdx);
 
         /**
          * Return the result of executing this query with the given parameter
-         * values.  Most implementation will use
+         * values. Most implementation will use
          * {@link QueryContext#toParameterArray} to transform the parameters
          * into an array and invoke the array version of this method.
          */
@@ -226,13 +225,13 @@
         /**
          * Extract the value of the <code>orderIndex</code>th ordering
          * expression in {@link Query#getOrderingClauses} from the
-         * given result object.  The result object will be an object from
+         * given result object. The result object will be an object from
          * the result object provider returned from {@link #executeQuery}.
          * This method is used when several result lists have to be merged
-         * in memory.  If this exeuctor's parent query supports executors on
+         * in memory. If this exeuctor's parent query supports executors on
          * abstract or interface classes, this method will not be used.
          *
-         * @see    StoreQuery#supportsAbstractExecutor
+         * @see StoreQuery#supportsAbstractExecutor
          */
         public Object getOrderingValue(StoreQuery q, Object[] params,
             Object resultObject, int orderIndex);
@@ -245,7 +244,7 @@
 
         /**
          * Return true if this executor packs projections into the result
-         * class itself.  Executors for query languages that allow projections
+         * class itself. Executors for query languages that allow projections
          * without result clauses must return true and perform the result
          * packing themselves.
          */
@@ -305,9 +304,8 @@
         public Class getResultClass(StoreQuery q);
 
         /**
-         *	Return a map of {@link FieldMetaData} to update
-		 *	{@link Constant}s, in cases where this query is
-		 *	for a bulk update.
+         * Return a map of {@link FieldMetaData} to update
+		 * {@link Constant}s, in cases where this query is for a bulk update.
 	 	 */
 		public Map getUpdates (StoreQuery q);
 	}

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TCleanState.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TCleanState.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TCleanState.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TCleanState.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,11 +16,10 @@
 package org.apache.openjpa.kernel;
 
 /**
- * <p>Lifecycle state.</p>
- * <p/>
- * <p>Represents a transient instance that is managed by a StateManager and
+ * Lifecycle state.
+ *  Represents a transient instance that is managed by a StateManager and
  * may be participating in the current	transaction, but has not yet been
- * modified.</p>
+ * modified.
  *
  * @author Abe White
  */

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TDirtyState.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TDirtyState.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TDirtyState.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TDirtyState.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,10 +16,9 @@
 package org.apache.openjpa.kernel;
 
 /**
- * <p>Lifecycle state.</p>
- * <p/>
- * <p>Represents a transient instance that is participating in the current
- * transaction, and has been modified.</p>
+ * Lifecycle state.
+ *  Represents a transient instance that is participating in the current
+ * transaction, and has been modified.
  *
  * @author Abe White
  */

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TLoadedState.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TLoadedState.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TLoadedState.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TLoadedState.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,12 +16,11 @@
 package org.apache.openjpa.kernel;
 
 /**
- * <p>Lifecycle state.</p>
- * <p/>
- * <p>Represents a temporarily managed transient instance whose fields
+ * Lifecycle state.
+ *  Represents a temporarily managed transient instance whose fields
  * are loaded for the purpose of field inspection such
- * as for cascades.  This state should be released as soon as inspection
- * is complete.</p>
+ * as for cascades. This state should be released as soon as inspection
+ * is complete.
  *
  * @author Steve Kim
  */

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TimeSeededSeq.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TimeSeededSeq.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TimeSeededSeq.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TimeSeededSeq.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,
@@ -24,9 +24,9 @@
 ////////////////////////////////////////////////////////////
 
 /**
- * <p>A simplistic implementation of a {@link Seq} used
- * to provide datastore ids.  Starts with an id equal to the system's
- * current time in milliseconds and increments from there.</p>
+ * A simplistic implementation of a {@link Seq} used
+ * to provide datastore ids. Starts with an id equal to the system's
+ * current time in milliseconds and increments from there.
  *
  * @author Greg Campbell
  */

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TransferFieldManager.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TransferFieldManager.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TransferFieldManager.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TransferFieldManager.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,7 +18,7 @@
 import org.apache.openjpa.enhance.FieldManager;
 
 /**
- * <p>FieldManager type used to transfer a single field value.</p>
+ * FieldManager type used to transfer a single field value.
  *
  * @author Abe White
  */
@@ -124,8 +124,7 @@
     }
 
     /**
-     * Clear any held state.  Fields are also cleared automatically when
-     * fetched.
+     * Clear any held state. Fields are also cleared automatically when fetched.
      */
     public void clear() {
         dblval = 0;

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TransientState.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TransientState.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TransientState.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/TransientState.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,11 +16,10 @@
 package org.apache.openjpa.kernel;
 
 /**
- * <p>Lifecycle state.</p>
- * <p/>
- * <p>Represents a transient instance; this state lasts only through
+ * Lifecycle state.
+ *  Represents a transient instance; this state lasts only through
  * the {@link #initialize} method, which immediately removes the
- * persistence capable instance from management by the OpenJPA runtime.</p>
+ * persistence capable instance from management by the OpenJPA runtime.
  *
  * @author Abe White
  */

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/UUIDHexSeq.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/UUIDHexSeq.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/UUIDHexSeq.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/UUIDHexSeq.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.ClassMetaData;
 
 /**
- * <p>Sequence for generating 32-character hex UUID strings.</p>
+ * Sequence for generating 32-character hex UUID strings.
  *
  * @author Abe White
  */

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/UUIDStringSeq.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/UUIDStringSeq.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/UUIDStringSeq.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/UUIDStringSeq.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.ClassMetaData;
 
 /**
- * <p>Sequence for generating 16-character UUID strings.</p>
+ * Sequence for generating 16-character UUID strings.
  *
  * @author Abe White
  */

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/VersionAttachStrategy.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/VersionAttachStrategy.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/VersionAttachStrategy.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/VersionAttachStrategy.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,
@@ -288,7 +288,7 @@
     }
 
     /**
-     *	Attach the given map.
+     * Attach the given map.
      */
     private Map attachInPlace(AttachManager manager, StateManagerImpl sm,
         FieldMetaData fmd, Map map) {

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/VersionLockManager.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/VersionLockManager.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/VersionLockManager.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/VersionLockManager.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,8 +20,7 @@
 /**
  * {@link LockManager} implementation that provides support
  * for version checking and version updating when locks are acquired.
- * This lock manager may be used standalone or extended for additional
- * locking.
+ * This lock manager may be used standalone or extended for additional locking.
  *
  * @author Marc Prud'hommeaux
  */
@@ -33,8 +32,8 @@
 
     /**
      * Returns the given instance's lock level, assuming that the state's
-     * lock object is a number.  If the given instance is embedded, traverses
-     * to its owner.  Override if lock is not stored as a number.
+     * lock object is a number. If the given instance is embedded, traverses
+     * to its owner. Override if lock is not stored as a number.
      */
     public int getLockLevel(OpenJPAStateManager sm) {
         while (sm.getOwner() != null)
@@ -44,7 +43,7 @@
     }
 
     /**
-     * Sets the given instance's lock level to the given number.  Override
+     * Sets the given instance's lock level to the given number. Override
      * to store something else as the lock.
      */
     protected void setLockLevel(OpenJPAStateManager sm, int level) {
@@ -61,7 +60,7 @@
     /**
      * Delegates to {@link #lockInternal} after traversing to owning
      * instance (if embedded) and assuring that the instance is persistent,
-     * is not new, and is not already locked at a higher level.  After
+     * is not new, and is not already locked at a higher level. After
      * locking, calls {@link #setLockLevel} with the given level.
      */
     public void lock(OpenJPAStateManager sm, int level, int timeout,
@@ -89,7 +88,7 @@
     /**
      * Marks the instance's transactional status in accordance with
      * the settings of {@link #getVersionCheckOnReadLock}
-     * and {@link #getVersionUpdateOnWriteLock}.  Override to perform
+     * and {@link #getVersionUpdateOnWriteLock}. Override to perform
      * additional locking.
      *
      * @see StoreContext#transactional
@@ -105,7 +104,7 @@
     /**
      * Whether or not we should force a version check at commit
      * time when a read lock is requested in order to verify read
-     * consistency.  Defaults to true.
+     * consistency. Defaults to true.
      */
     public void setVersionCheckOnReadLock(boolean versionCheckOnReadLock) {
         _versionCheckOnReadLock = versionCheckOnReadLock;
@@ -114,7 +113,7 @@
     /**
      * Whether or not we should force a version check at commit
      * time when a read lock is requested in order to verify read
-     * consistency.  Defaults to true.
+     * consistency. Defaults to true.
      */
     public boolean getVersionCheckOnReadLock() {
         return _versionCheckOnReadLock;
@@ -122,19 +121,18 @@
 
     /**
      * Whether or not we should force an update to the version at commit
-     * time when a write lock is requested.  Defaults to true.
+     * time when a write lock is requested. Defaults to true.
      */
     public void setVersionUpdateOnWriteLock(boolean versionUpdateOnWriteLock) {
         _versionUpdateOnWriteLock = versionUpdateOnWriteLock;
     }
 
     /**
-     *  Whether or not we should force an update to the version at commit
-     *  time when a write lock is requested.  Defaults to true.
+     * Whether or not we should force an update to the version at commit
+     * time when a write lock is requested. Defaults to true.
      */
     public boolean getVersionUpdateOnWriteLock() {
         return _versionUpdateOnWriteLock;
 	}
 }
-
 

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Abs.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Abs.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Abs.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Abs.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,7 +22,7 @@
 import serp.util.Numbers;
 
 /**
- * <p>Take the absolute value of a number.</p>
+ * Take the absolute value of a number.
  *
  * @author Abe White
  */
@@ -30,7 +30,7 @@
     extends UnaryMathVal {
 
     /**
-     * Constructor.  Provide the number whose absolute value to calculate.
+     * Constructor. Provide the number whose absolute value to calculate.
      */
     public Abs(Val val) {
         super(val);

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/AbstractExpressionBuilder.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/AbstractExpressionBuilder.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/AbstractExpressionBuilder.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/AbstractExpressionBuilder.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,
@@ -73,9 +73,9 @@
     /**
      * Constructor.
      *
-     * @param    factory        the expression factory to use
-     * @param    meta        candidate class metadata
-     * @param    resolver    used to resolve variables, parameters, and class
+     * @param factory the expression factory to use
+     * @param meta candidate class metadata
+     * @param resolver used to resolve variables, parameters, and class
      * names used in the query
      */
     public AbstractExpressionBuilder(ExpressionFactory factory,
@@ -180,7 +180,7 @@
     }
 
     /**
-     * Validate that all unbound variables are of a PC type.  If not, assume
+     * Validate that all unbound variables are of a PC type. If not, assume
      * that the user actually made a typo that we took for an implicit
      * unbound variable.
      */
@@ -477,7 +477,7 @@
     protected abstract Localizer getLocalizer();
 
     /**
-     *  Returns the current string being parsed; used for error messages.
+     * Returns the current string being parsed; used for error messages.
 	 */
 	protected abstract String currentQuery ();
 }

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Add.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Add.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Add.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Add.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,7 +18,7 @@
 import org.apache.openjpa.kernel.Filters;
 
 /**
- * <p>Value produced by two values being added together.</p>
+ * Value produced by two values being added together.
  *
  * @author Abe White
  */
@@ -26,7 +26,7 @@
     extends MathVal {
 
     /**
-     * Constructor.  Provide the values to add.
+     * Constructor. Provide the values to add.
      */
     public Add(Val val1, Val val2) {
         super(val1, val2);

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Aggregate.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Aggregate.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Aggregate.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Aggregate.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.util.UserException;
 
 /**
- * <p>A value produced from evaluating a result aggregate.</p>
+ * A value produced from evaluating a result aggregate.
  *
  * @author Abe White
  */
@@ -36,7 +36,7 @@
     private final Val _arg;
 
     /**
-     * Constructor.  Supply aggregate listener and its argument value, if any.
+     * Constructor. Supply aggregate listener and its argument value, if any.
      */
     public Aggregate(AggregateListener listener, Val arg) {
         _listener = listener;

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/AggregateListener.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/AggregateListener.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/AggregateListener.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/AggregateListener.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,7 +21,7 @@
 import org.apache.openjpa.kernel.StoreContext;
 
 /**
- * <p>An aggregate listener aggregates data produced by an ExpressionQuery.</p>
+ * An aggregate listener aggregates data produced by an ExpressionQuery.
  *
  * @author Abe White
  * @author Patrick Linskey
@@ -45,13 +45,13 @@
     /**
      * Return the value of this aggregate.
      *
-     * @param    args        for each candidate, the value of the arguments to
+     * @param args for each candidate, the value of the arguments to
      * the function; will be null if this aggregate does
      * not expect an argument; if this function has
      * multiple arguments, each element will be an array
-     * @param    argClasses    the expected class of each argument element
-     * @param    candidates    the candidate objects being evaluated
-     * @param    ctx            the persistence context
+     * @param argClasses the expected class of each argument element
+     * @param candidates the candidate objects being evaluated
+     * @param ctx the persistence context
      * @return the value of the aggregate
      * @throws UserException if this aggregate does not support
      * in-memory operation
@@ -60,10 +60,10 @@
         Collection candidates, StoreContext ctx);
 
     /**
-     *	Return the expected type of the result of this listener.
+     * Return the expected type of the result of this listener.
      *
-     *	@param    argClasses    the expected classes of the argument, or null if
-     *						no arguments
+     * @param argClasses the expected classes of the argument, or null if
+     * no arguments
      */
     public Class getType(Class[] argClasses);
 }

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/AggregateVal.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/AggregateVal.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/AggregateVal.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/AggregateVal.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.util.UserException;
 
 /**
- * <p>An aggregate of some value.</p>
+ * An aggregate of some value.
  *
  * @author Abe White
  */
@@ -36,7 +36,7 @@
     private final Val _val;
 
     /**
-     * Constructor.  Supply value to aggregate.
+     * Constructor. Supply value to aggregate.
      */
     public AggregateVal(Val val) {
         _val = val;
@@ -82,7 +82,7 @@
     protected abstract Class getType(Class c);
 
     /**
-     *	Aggregate the given values.
+     * Aggregate the given values.
      */
     protected abstract Object operate(Collection os, Class c);
 }

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/All.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/All.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/All.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/All.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,8 +23,8 @@
 import org.apache.openjpa.util.UnsupportedException;
 
 /**
- * <p>In-memory All implementation. Currently unsupported since
- * in-memory subqueries are not supported.</p>
+ * In-memory All implementation. Currently unsupported since
+ * in-memory subqueries are not supported.
  *
  * @author Marc Prud'hommeaux
  */

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/AndExpression.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/AndExpression.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/AndExpression.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/AndExpression.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,7 +20,7 @@
 import org.apache.openjpa.kernel.StoreContext;
 
 /**
- * <p>An expression that AND's two others together.</p>
+ * An expression that AND's two others together.
  *
  * @author Abe White
  */
@@ -31,7 +31,7 @@
     private final Exp _exp2;
 
     /**
-     * Constructor.  Supply expressions to combine.
+     * Constructor. Supply expressions to combine.
      */
     public AndExpression(Exp exp1, Exp exp2) {
         _exp1 = exp1;

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Any.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Any.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Any.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Any.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,8 +23,8 @@
 import org.apache.openjpa.util.UnsupportedException;
 
 /**
- * <p>In-memory Any implementation. Currently unsupported since
- * in-memory subqueries are not supported.</p>
+ * In-memory Any implementation. Currently unsupported since
+ * in-memory subqueries are not supported.
  *
  * @author Marc Prud'hommeaux
  */

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Args.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Args.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Args.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Args.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,7 +21,7 @@
 import org.apache.openjpa.kernel.StoreContext;
 
 /**
- * <p>A list of arguments to a multi-argument function.</p>
+ * A list of arguments to a multi-argument function.
  *
  * @author Abe White
  */
@@ -32,7 +32,7 @@
     private final List _args = new ArrayList(3);
 
     /**
-     * Constructor.  Supply values being combined.
+     * Constructor. Supply values being combined.
      */
     public Args(Value val1, Value val2) {
         if (val1 instanceof Args)

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Arguments.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Arguments.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Arguments.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Arguments.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.exps;
 
 /**
- * <p>Multiple arguments to a function call.</p>
+ * Multiple arguments to a function call.
  *
  * @author Abe White
  */

Modified: incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Avg.java
URL: http://svn.apache.org/viewvc/incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Avg.java?rev=421741&r1=421740&r2=421741&view=diff
==============================================================================
--- incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Avg.java (original)
+++ incubator/openjpa/trunk/openjpa-kernel/src/main/java/org/apache/openjpa/kernel/exps/Avg.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,7 +22,7 @@
 import serp.util.Numbers;
 
 /**
- * <p>Average values.</p>
+ * Average values.
  *
  * @author Abe White
  */
@@ -30,7 +30,7 @@
     extends AggregateVal {
 
     /**
-     * Constructor.  Provide the value to average.
+     * Constructor. Provide the value to average.
      */
     public Avg(Val val) {
         super(val);