You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@openjpa.apache.org by st...@apache.org on 2013/10/30 20:29:59 UTC

svn commit: r1537254 - in /openjpa/branches/2.3.x/openjpa-project: CHANGES.txt RELEASE-NOTES.html

Author: struberg
Date: Wed Oct 30 19:29:58 2013
New Revision: 1537254

URL: http://svn.apache.org/r1537254
Log:
adopt release notes and changes files for 2.3.0 release

Modified:
    openjpa/branches/2.3.x/openjpa-project/CHANGES.txt
    openjpa/branches/2.3.x/openjpa-project/RELEASE-NOTES.html

Modified: openjpa/branches/2.3.x/openjpa-project/CHANGES.txt
URL: http://svn.apache.org/viewvc/openjpa/branches/2.3.x/openjpa-project/CHANGES.txt?rev=1537254&r1=1537253&r2=1537254&view=diff
==============================================================================
--- openjpa/branches/2.3.x/openjpa-project/CHANGES.txt (original)
+++ openjpa/branches/2.3.x/openjpa-project/CHANGES.txt Wed Oct 30 19:29:58 2013
@@ -1,4 +1,4 @@
-Apache OpenJPA 2.2.0
+Apache OpenJPA 2.3.0
 Licensed under Apache License 2.0 - http://www.apache.org/licenses/LICENSE-2.0
 --------------------------------------------------------------------------------
 
@@ -21,7 +21,7 @@ Content
 Overview
 --------
    The Apache OpenJPA community is proud to release a SNAPSHOT distribution of
-   OpenJPA 2.2.0. This distribution is based on the final JSR 317 Java 
+   OpenJPA 2.3.0. This distribution is based on the final JSR 317 Java 
    Persistence API, Version 2.0 specification and passes the JPA 2.0 TCK,
    while remaining backwards compatible with prior releases based on the
    Java Persistence API (JPA 1.0) part of Java Community Process JSR-220
@@ -54,7 +54,7 @@ License
 
 Notices
 -------
-   Copyright 2006,2012 The Apache Software Foundation.
+   Copyright 2006,2013 The Apache Software Foundation.
    Apache, the Apache feather logo and OpenJPA are trademarks of
    The Apache Software Foundation.
 
@@ -112,167 +112,162 @@ Getting Involved
           https://issues.apache.org/jira/browse/OPENJPA
 
 
-Included Changes in OpenJPA 2.2.0
+Included Changes in OpenJPA 2.3.0
 ---------------------------------
 
 Sub-task
 
-    [OPENJPA-1593] - Create an OSGiManagedRuntime
-    [OPENJPA-2081] - Provide subset of XML support for OpenJPA annotations
+    [OPENJPA-2168] - Do not go through LifeCycleEventManager overhead if the Entity has declared to be excluded
 
 Bug
 
-    [OPENJPA-478] - Contradictory text in manual section 10.2.6. JPQL GROUP BY, HAVING
-    [OPENJPA-867] - Unexpected Behaviour of DBDictionary.indexOf() method
-    [OPENJPA-1343] - Incorrect example of openjpa.Sequence property
-    [OPENJPA-1376] - @SequenceGenerator allocationSize incorrect implementation
-    [OPENJPA-1650] - Adding a slice dynamically should be done via persistence unit only
-    [OPENJPA-1651] - Unique colums automatically defined as non-nullable (part 2)
-    [OPENJPA-1657] - Postgres connection throws NPE with null properties
-    [OPENJPA-1686] - Persistence of Dynamic and Generic Type
-    [OPENJPA-1725] - Schemaname wrongly included in DBDictionary.checkNameLength after Tablename correctly truncated
-    [OPENJPA-1746] - NullPointerException when a null value is set in the properties map passed to Entity.createEntityManagerFactory
-    [OPENJPA-1768] - StackOverflowError when finding an Entity with an Eager ManyToMany relationship.
-    [OPENJPA-1787] - Bean validation fails merging a new entity
-    [OPENJPA-1845] - the prepared query cache doesn't currently work correclty with 'SELECT IN' statements
-    [OPENJPA-1856] - Executing bulk updates should evict stale data from the DataCache
-    [OPENJPA-1873] - EntityManager#merge sometimes passes wrong entity values to @PostLoad EntityListeners
-    [OPENJPA-1876] - Slow JDBC tests
-    [OPENJPA-1896] - OpenJPA cannot store POJOs if a corresponding record already exists
-    [OPENJPA-1898] - TestQueryMultiThreaded fails with OOME "unable to create new native thread"
-    [OPENJPA-1900] - ClassCastException when serializing an entity if DetachedStateField=true
+    [OPENJPA-696] - Cache TransactionSynchronizationRegistry per EMF (vs JVM)
+    [OPENJPA-1794] - Result of aggregate function MAX is 0 on empty table (instead of NULL).
+    [OPENJPA-1819] - ORDER BY will append additional column to the SELECT clause which may potentialy cause ORA-00979 error
     [OPENJPA-1901] - QueryCacheStoreQuery$CachedObjectId that is not Serializable
-    [OPENJPA-1902] - SQLServer reserved words may not be used as identifiers
-    [OPENJPA-1903] - Some queries only work the first time they are executed
-    [OPENJPA-1904] - OptimisticLockException during refresh(*,PESSIMISTIC_*) with eagar fetch on relationship fields
-    [OPENJPA-1905] - jar-file validation should be deferred until after OpenJPA is confirmed to be the application's chosen provider
-    [OPENJPA-1906] - Issue info / warning message when connection retain mode is always
-    [OPENJPA-1909] - enhance unit tests with the correct persistence.xml
-    [OPENJPA-1910] - openjpa uses application ClassLoader for resolving BrokerFactory (revisited)
-    [OPENJPA-1911] - InvalidStateException is thrown when merge an entity with derived identiy
-    [OPENJPA-1912] - enhancer generates invalid code if fetch-groups is activated
-    [OPENJPA-1915] - missing license header
-    [OPENJPA-1918] - MetaDataRepository.preload() ignores class loader returned by PersistenceUnitInfo.getClassLoader()
-    [OPENJPA-1923] - Allow flexible (non-standard) syntax for collection-valued parameters in IN() expresseion of JPQL query
-    [OPENJPA-1928] - Resolving factory method does not allow method overriding
-    [OPENJPA-1932] - Documentation corrections
-    [OPENJPA-1935] - Informix lock exceptions are not mapped properly by OpenJPA
-    [OPENJPA-1938] - Typo of time data type in SQLServerdictionary for MSSQL 2008
-    [OPENJPA-1939] - index identifier max length for DB2 v9 is 128.
-    [OPENJPA-1940] - ReverseMapping tool does not find primary keys with Oracle
-    [OPENJPA-1941] - Criteria query returns wrong result when query cache is enabled
-    [OPENJPA-1943] - Query timeout hint not honored consistently when pessimistic lock is issued to database requires multi-statements locking scheme
-    [OPENJPA-1944] - Extra select statements executed when version column is null.
-    [OPENJPA-1951] - missing key "cant-set-value" in localizer properties org.apache.openjpa.jdbc.meta.strats
-    [OPENJPA-1953] - Copying data from inputStream to OuputStream needs appropriate buffer size
-    [OPENJPA-1954] - ArrayIndexOutOfBoundsException when querying on a version field that is in a MappedSuperclass
-    [OPENJPA-1957] - XML overriding column names for ArrayList attributes causes exception.
-    [OPENJPA-1958] - IndexOutOfBoundsException in BatchingPreparedStatementManagerImpl
-    [OPENJPA-1959] - RuntimeExceptionTranslator should be transient in DelegatingQuery
-    [OPENJPA-1960] - openjpa.InitializeEagerly breaks bean-validation integration
-    [OPENJPA-1965] - ClassCastException when using JAXB and MetaModel annotation processor
-    [OPENJPA-1968] - SQLServerDictionery not using DATETIME2 for jdbc driver other than MS JDBC driver
-    [OPENJPA-1969] - SQLServer / DataDirect SQLCode=HYT00 not handled
-    [OPENJPA-1974] - StackOverflowError when performing multiple subquery in collection field with eager fetch
-    [OPENJPA-1975] - Only obtain default schema name when needed (DB2)
-    [OPENJPA-1981] - Improper cleanup in SchemaGenerator
-    [OPENJPA-1983] - Merge of lazily fetched fields, and merge of managed entities deviates from spec
-    [OPENJPA-1984] - Incorrect ViolationContraint getRootBean when removing bean with embedded entity validation
-    [OPENJPA-1985] - ClassCastException in max(Timestamp) function on PostgreSQL
-    [OPENJPA-1986] - Extra queries being generated when cascading a persist
-    [OPENJPA-1987] - Postgres / Ingres does not support null table for getImportedKeys
-    [OPENJPA-1989] - *ToOne relationships specified as LAZY in xml aren't honored
-    [OPENJPA-1992] - java.lang.ArrayIndexOutOfBoundsException if positional parameter are not started from 1
-    [OPENJPA-1994] - Index is a reserved word for MySQL
-    [OPENJPA-1996] - OpenJPA Samples fail on MacOS X
-    [OPENJPA-1998] - NPE getTableNameForMetadata when running SchemaTool reflect against Postgres DB
-    [OPENJPA-2000] - Wrong PostgreSQL data type for REAL - "float8", must be "float4"
-    [OPENJPA-2005] - PostgresDictionary.isOwnedSequence needs a null check
-    [OPENJPA-2006] - Sequence generated ids may fail to get assigned when flushing a graph with bi-directional relationships
-    [OPENJPA-2007] - Setting query hint "openjpa.FetchPlan.Isolation" results in misleading warning
-    [OPENJPA-2008] - OpenJPA does not work with native queries in a distributed (Slice) environment
-    [OPENJPA-2010] - Duplicate meta data warning logged due to parsing the same location twice
-    [OPENJPA-2011] - Prevent reparsing annotation metadata for queries
-    [OPENJPA-2013] - columnDefinition for TEXT types ends up in wrong sql statement
-    [OPENJPA-2025] - Byte[] and Char[] should be treated as SingularAttributes, not lists by the metamodel generator
-    [OPENJPA-2027] - Metamodel genereated at runtime expects ListAttribute for all arrays - not just PersistentCollections.
-    [OPENJPA-2034] - Update H2 Database sql error codes as per the changes in v1.3.154
-    [OPENJPA-2036] - DynamicEnhancer should look for tools.jar in java.home/lib for all JDKs, not just the IBM SDK.
-    [OPENJPA-2039] - FKs for EAGER fields that are not in the current fetchplan aren't selected
-    [OPENJPA-2044] - Invalid header in MetaModel classes generated by AnnotationProcessor
-    [OPENJPA-2045] - NAME is a valid column name for H2 databases.
-    [OPENJPA-2051] - Entities in a relationship are not properly cascaded after a EntityManager.flush is executed.
-    [OPENJPA-2056] - Postgres V9.1 issue with LIKE clause and Escape Strings
-    [OPENJPA-2059] - Missing localizer.properties for org.apache.openjpa.persistence.util.SourceCode
-    [OPENJPA-2060] - AnnotationProcess failed to generate metadata for List<String>[] attribute in entity
-    [OPENJPA-2065] - JPA 2.0 Spec. Violation? EntityManager#createNamedQuery(String, Class) bombs with non-entity Class parameter
-    [OPENJPA-2066] - Edge case in openJPA-1227. openJPA fails to create a join and thus returns wrong data when a collection is selected from superclass and another field is selected from subclass twoor more levels down the hierarchy.
-    [OPENJPA-2069] - Natvie sequence problems uncovered after OPENJPA-1376
-    [OPENJPA-2070] - Error processing while populating Metamodel classes needs improvement
-    [OPENJPA-2071] - NPE during ResultPacker interface processing
-    [OPENJPA-2073] - MappingTools requires live connection to DB2 server to retrieve default schema name
-    [OPENJPA-2076] - Minor fix-ups to messages
-    [OPENJPA-2077] - Pom references to org.codehaus.mojo openjpa-maven-plugin cause problems
-    [OPENJPA-2083] - Unmapped fields silently treated as transient
-    [OPENJPA-2100] - openjpa-maven-plugin fails to create SQL for entities which contain enums
-    [OPENJPA-2101] - PersistenceProductDerivation overwrites the RemoteCommitProvider configuration
-    [OPENJPA-2104] - BindParameter is not a valid query parameter as processed in DBDictionary's setUnknown()
-    [OPENJPA-2105] - Document changes no longer being uploaded
-    [OPENJPA-2107] - ManagedCache conflict due adding an entity 2 times in the same query.
-    [OPENJPA-2117] - XML overriding column names for 1xM attributes causes exception.
-    [OPENJPA-2119] - Update org.apache.openjpa.persistence.util.SourceCode
-    [OPENJPA-2122] - VerifyError with Java 7 when using javaagent or dynamic container enhancement
-    [OPENJPA-2124] - Use of XMLValueHandler results in a NullPointerException when classloader does not provide package support
+    [OPENJPA-1979] - Regression for non-standard joins with constant column values
+    [OPENJPA-1993] - Deadlock Potential with ORM XML Processing
+    [OPENJPA-2018] - Cannot bind String[] to ParameterExpression for path.in(parameter)
+    [OPENJPA-2067] - A 'length' of '-1' passed to PreparedStatement.setBinaryStream can cause an exception on some, but not all, JDBC drivers.
+    [OPENJPA-2072] - InvalidStateException deleting an instance with a timestamp in its primary key
+    [OPENJPA-2095] - Unhandled exception thrown from within an Externalizer method causes incorrect/incomplete SQL to be generated/executed.
+    [OPENJPA-2102] - URLs which contains spaces are not properly handled by OpenJPA.
+    [OPENJPA-2110] - Abstract entity causes standard openjpa collection proxies to be injected even if custom collections are used.
+    [OPENJPA-2118] - Prepared SQL query does not handle collection-valued parameter where collection is empty
+    [OPENJPA-2123] - Minor performance improvements for Connection and ResultSet processing
+    [OPENJPA-2131] - Missing IN or OUT parameter exception with OracleDictionary
+    [OPENJPA-2132] - Traversal of a OneToMany relationship returns an empty list when InheritanceType.JOINED or SINGLE_TABLE is used.
+    [OPENJPA-2133] - OpenJPA doesn't find custom mappings with an applicable class loader
+    [OPENJPA-2136] - NPE when using LiteAutoDetach
+    [OPENJPA-2140] - Locking tests issue many warnings about the use of a duplicate pu name
+    [OPENJPA-2142] - Merge of a new object does not handle Entity Id field
+    [OPENJPA-2145] - Missing ASM depending jar in binary zip
+    [OPENJPA-2146] - StateManager for Embeddable may throw Exception while initializing
+    [OPENJPA-2149] - Criteria.function adds wrong casts to parameters making it unsuable
+    [OPENJPA-2153] - NoSuchMethodException of DBCPDriverDataSource.newInstance()
+    [OPENJPA-2154] - test-dynamic-enhancer profile failed for module more than one level deep
+    [OPENJPA-2156] - Fix bug in org.apache.openjpa.persistence.util.SourceCode to correctly generate imports.
+    [OPENJPA-2158] - LiteAutoDetach + DetachProxyFields=false can lead to Broker concurrency exceptions
+    [OPENJPA-2161] - Make some members of StateManagerImpl protected to allow for greater extensability
+    [OPENJPA-2163] - Lifecycle event callback occurs more often than expect
+    [OPENJPA-2170] - Multiple INSERT of the same row in batch update manager
+    [OPENJPA-2172] - openjpa-all jar is missing slf4j runtime dependency
+    [OPENJPA-2174] - Result set mapping was not looked up when retrieving column data from a NamedNativeQuery
+    [OPENJPA-2178] - PostgresDictionary
+    [OPENJPA-2180] - OpenJPA build broken in java7 / jdk-1.7
+    [OPENJPA-2187] - metamodel generation with default package creates invalid class
+    [OPENJPA-2191] - QueryCache don't allow for misconfigurations
+    [OPENJPA-2196] - Create Sequence Postgres 9.1
+    [OPENJPA-2197] - MethodComparator in AnnotationPersistenceMetaDataParser should also compare parameters
+    [OPENJPA-2199] - Constraint violation exception when removing relationship using (orphanRemoval = true)
+    [OPENJPA-2204] - NPE in JDBCStoreManager with Trace turned on
+    [OPENJPA-2221] - Use of AbstractValueHandler map() causes exception on find()
+    [OPENJPA-2227] - OpenJPA doesn't find custom SequenceGenerators
+    [OPENJPA-2228] - QuerySQLCache broken for Entities with @EmbeddedId
+    [OPENJPA-2229] - Persistence entities not recognized when deploying on JBoss AS 7.1
+    [OPENJPA-2230] - Event Listener detection didn't work with MappedSuperClasses or Entity heirarchies
+    [OPENJPA-2234] - EntityManager instance creation needs TX activity
+    [OPENJPA-2235] - "READ_UNCOMMITTED" setting for the fetch plan isolation level is ignored in DB2Dictionary
+    [OPENJPA-2236] - Trace of connection info can cause class transform/enhancement to fail
+    [OPENJPA-2238] - IllegalAccessError when trying to proxy a default scoped Class
+    [OPENJPA-2240] - JVMVRFY012 when using openjpa together with hyperjaxb3
+    [OPENJPA-2244] - Nested classpath ignored in mapping tool ant task
+    [OPENJPA-2245] - NotSerializableException when using a remote QueryCache and the Criteria API
+    [OPENJPA-2247] - JoinColumn annotation is ignored when mapping a unidirectional owned OneToOne that is in a SecondaryTable
+    [OPENJPA-2253] - Memory leak in Audit feature
+    [OPENJPA-2255] - Couldn't load the referencedColumn definition when create the JoinTable
+    [OPENJPA-2257] - Concurreny in org.apache.openjpa.persistence.EntityManagerImpl.getProperties leads to NullPointer and ConcurrentModificationException
+    [OPENJPA-2260] - Parenthesis-augmented parameters are improperly processed at EM level
+    [OPENJPA-2261] - Query SQL Cache issue with NULL parameters
+    [OPENJPA-2267] - native query select with null result causes NullPointerException
+    [OPENJPA-2269] - Duplicate key exception in sequence table on multithreaded initialization
+    [OPENJPA-2271] - Old <ciManagement/> info on root POM
+    [OPENJPA-2282] - ESCAPE '\' is appended to the like clause unexpectedly
+    [OPENJPA-2284] - NPE occurs when <cascade-persist/> is added to a <persistence-unit-defaults> in an orm.
+    [OPENJPA-2288] - MetaDataRepository should be able to filter classes from other app ClassLoaders in JEE Env
+    [OPENJPA-2289] - Additional SQL alias generated for query with subquery causes incorrect # of rows returned - Oracle only
+    [OPENJPA-2298] - VerifyError/Stack underflow due to extra 'return' statements generated by PCEnhancer.
+    [OPENJPA-2304] - Thread deadlock in CriteriaBuilder
+    [OPENJPA-2305] - Canonical MetaModel class generation should not use inhertence
+    [OPENJPA-2318] - Left outer join is not generated when specifien using Criteria API
+    [OPENJPA-2320] - CriteriaBuilder predicate construction deadlocks in multi-core VM due to static initializer
+    [OPENJPA-2321] - Synchronizing logging output stream causes deadlock when used some JDK LogManger derivative
+    [OPENJPA-2325] - MappedSuperClass without an @Id causes wrong identity type for the inherited types
+    [OPENJPA-2326] - Updates in TCK execution configuration
+    [OPENJPA-2328] - NPE caused by one too many calls on the iterator inside the library.
+    [OPENJPA-2330] - Stackoverflow due to endless recursive calls
+    [OPENJPA-2334] - OpenJPA must support processing puRoot & jar-file URLs as jar-formatted InputStreams
+    [OPENJPA-2335] - Constrained foreign key column value setting needs to be flexible
+    [OPENJPA-2336] - Relax Join column name comparison based on database dictionary schema case setting
+    [OPENJPA-2343] - Version field returns null when explicity projected from a JOIN in SELECT clause
+    [OPENJPA-2355] - CONCAT() function must support more than two arguments
+    [OPENJPA-2357] - @..ToMany(optional=false) throws InvalidStateException: [...] the metadata for this field specifies that nulls are illegal.
+    [OPENJPA-2377] - Metamodel.managedType returns wrong result for Embeddable
+    [OPENJPA-2378] - TestHandlerStrategy.testIssue_OPENJPA2328 failed with Oracle
+    [OPENJPA-2384] - Rendering criteria query to JPQL-like string ignores multiple GROUP BY clauses
+    [OPENJPA-2390] - HSQLDB SELECT NEXT VALUE FOR Sequence will skip 1 sequence value if allocation size is 1
+    [OPENJPA-2391] - HSQLDB v2.2.9
+    [OPENJPA-2400] - Support MariaDB
+    [OPENJPA-2405] - EntityManager.merge does not work for entity that is managed by another EntityManager
+    [OPENJPA-2409] - allow the openjpa-maven-plugin to use a persistence.xml from resources and not only from files
+    [OPENJPA-2414] - FinderCache does not consider active Fetch Groups/FetchPlan added Fields
+    [OPENJPA-2418] - Cannot build 2.2.x due to NullPointerException in maven-checkstyle-plugin
+    [OPENJPA-2421] - Slices: Can't setting up FinderTargetPolicy
+    [OPENJPA-2425] - SELECT fields with @ExternalValues defined returns datastore values instead of unmapped fields
+    [OPENJPA-2432] - MySQL dictionary can't be found from a valid connection
+    [OPENJPA-2435] - Version field in a projection always returned as an Integer.
+    [OPENJPA-2437] - transactional listeners added too late to observe begin event
+    [OPENJPA-2440] - foreign key drop leaks jdbc connections
+    [OPENJPA-2443] - InvalidStateException while merging a new Entity with a GeneratedValue id
+    [OPENJPA-2444] - ReverseMappingTool creates orm.xml files in the current working directory
 
 Improvement
 
-    [OPENJPA-302] - PCEnhancer needs target classes on classpath
-    [OPENJPA-487] - Generated SUBSTRING SQL is ugly and inefficient
-    [OPENJPA-758] - OpenJPA doesn't find ValueHandlers with an applicable class loader
-    [OPENJPA-1555] - SQLBuffer code cleanup
-    [OPENJPA-1777] - Allow setting of diagonstic context for each slice in a more flexible manner
-    [OPENJPA-1778] - Improved error information for unenhanced classes.
-    [OPENJPA-1798] - Improve messages in localize.properties
-    [OPENJPA-1803] - Unwrap EntityManager to Connection
-    [OPENJPA-1847] - Use a single connection when generating schema
-    [OPENJPA-1863] - update HSQL dictionary for HSQLDB 2.0
-    [OPENJPA-1917] - Cache column alias in SelectImpl
-    [OPENJPA-1937] - Document OpenJPAEntityManager.evict methods
-    [OPENJPA-1945] - Improve aspects of the OpenBooks sample
-    [OPENJPA-1972] - DB2 V9.7 changed the default behavior concerning blocking behavior with isolation levels greater then read uncommitted
-    [OPENJPA-1990] - Skip getting extend exception text when running on DB2
-    [OPENJPA-1999] - Optional support for non-sequential positional parameters
-    [OPENJPA-2014] - Allow proxies to stay in place when Detaching
-    [OPENJPA-2020] - Make some members of StateManagerImpl protected to allow for greater extensability
-    [OPENJPA-2031] - Unable to import maven projects with m2e version 1.0
-    [OPENJPA-2042] - Diagnostics for Application Managed EntityManagerFactory leaks.
-    [OPENJPA-2043] - OpenJPAId hashCode() value needs to be consistent after serialization process
-    [OPENJPA-2047] - Document the impact of Persistence Aware classes
-    [OPENJPA-2068] - Improve performance of java.util.Calendar fields
-    [OPENJPA-2075] - Abstract out parameter handling / validation from org.apache.openjpa.persistence.QueryImpl to allow for greater extensibility
-    [OPENJPA-2084] - Upgrade Derby dependency to 10.8.x
-    [OPENJPA-2085] - Improve enhancement process to support JAVA 7 compliant class file generation
-    [OPENJPA-2087] - Remove or limit the use of the ConcreteClassGenerator
-    [OPENJPA-2116] - Scrape the barrel for performance juice
     [OPENJPA-2120] - Add new option to eliminate reflection calls from enhancer generated IdClass PC copy operations
-    [OPENJPA-2128] - Add a boolean to FieldMetaData to denote whether or not a field has a @EmbeddedId annotation.
-    [OPENJPA-2130] - Enable Java 7 testing by allowing test cases to compile targeting to 1.7
+    [OPENJPA-2134] - Do not close Connections when ConnectionRetainMode is set to "always"
+    [OPENJPA-2137] - Make some members of StateManagerImpl protected to allow for greater extensibility
+    [OPENJPA-2143] - Reduce lock contention on LifecycleEventManager
+    [OPENJPA-2151] - Improve the performance of StateManagerImpl.initialize
+    [OPENJPA-2152] - Don't process query hints when LockModeType == NONE
+    [OPENJPA-2159] - Add support for no rounding of Date
+    [OPENJPA-2162] - Avoid delimited identifier processing if it's not required by application
+    [OPENJPA-2164] - Don't setPCState if field requested is already loaded
+    [OPENJPA-2167] - Misc changes to improve flush() path performance
+    [OPENJPA-2171] - asm should be optional
+    [OPENJPA-2189] - Update OpenBooks example to build, install, and execute in the WAS Liberty Profile
+    [OPENJPA-2208] - Add additional Java 2 Security doPriv function
+    [OPENJPA-2209] - MetaDataRepository preload configuration should be more inclusive
+    [OPENJPA-2220] - Persistent field fetching statistic tool
+    [OPENJPA-2231] - jest TokenReplacedStream use Reader instead of Inputstream
+    [OPENJPA-2264] - Upcast PreparedStatementManagerImpl.logSQLWarnings to take a Statement rather than a PreparedStatement
+    [OPENJPA-2275] - Extending SchemaTool
+    [OPENJPA-2292] - Reduce object allocations
+    [OPENJPA-2293] - Reduce LifecycleEventManager
+    [OPENJPA-2324] - Option to express literal in query string directly into generate SQL
+    [OPENJPA-2332] - Update message when unable to resolve datasource configuration
+    [OPENJPA-2342] - Consider modifying PCEnhancer.run to use serp.bytecode.BCClass.getDeclaredInterfaceNames instead of getDeclaredInterfaceTypes.
+    [OPENJPA-2346] - Optimize MetaDataRepository.getMetaDataInternal
+    [OPENJPA-2347] - Make StateManagerImpl more extensible
+    [OPENJPA-2348] - Cache calculated hashCode in OpenJPAId
+    [OPENJPA-2353] - Reduce object allocations
+    [OPENJPA-2354] - Removed synchronized from enhancer added pcReplaceStateManager method
+    [OPENJPA-2368] - Move www.apache.org/openjpa/ns/orm to openjpa.apache.org/ns/orm
+    [OPENJPA-2410] - Build time detection of System.out/err.print(ln) in source files
 
 New Feature
 
-    [OPENJPA-184] - use DB2 Diagnostic interface to report extended error diagnostics on SQL Exception
-    [OPENJPA-1859] - Create a sample to demonstrate usage of JEST
-    [OPENJPA-1934] - contribute an openjpa-maven-plugin
-    [OPENJPA-2108] - Allow an option to terminate MappingTool-generated SQL with a character other than semicolon
+    [OPENJPA-2283] - Upgrade to ASM 4 dependency
+    [OPENJPA-2295] - speed up query metadata lookup
+    [OPENJPA-2366] - provide option to exclude schema name from generated @Table annotation for generated entities
+
+Question
+
+    [OPENJPA-1532] - Should the <shared-cache-mode> element in a persistence unit definition automatically turn on the data cache?
 
 Task
 
-    [OPENJPA-1786] - Upgrade to latest JPA 2.0 TCK
-    [OPENJPA-1834] - Upgrade trunk to use Deby 10.6.2.1 for junits
-    [OPENJPA-1875] - Add generics to the Graph code
-    [OPENJPA-2089] - upgrade bval to latest 0.3-incubating
-    [OPENJPA-2091] - update docbook maven plugin
+    [OPENJPA-2388] - support new xbean asm4 shade
 
 Test
 
-    [OPENJPA-2029] - Add PreparedQuery tests for non-sequential positional parameters support
+    [OPENJPA-2169] - TestOracleXmlColumn test failed using Oracle 11.2 driver

Modified: openjpa/branches/2.3.x/openjpa-project/RELEASE-NOTES.html
URL: http://svn.apache.org/viewvc/openjpa/branches/2.3.x/openjpa-project/RELEASE-NOTES.html?rev=1537254&r1=1537253&r2=1537254&view=diff
==============================================================================
--- openjpa/branches/2.3.x/openjpa-project/RELEASE-NOTES.html (original)
+++ openjpa/branches/2.3.x/openjpa-project/RELEASE-NOTES.html Wed Oct 30 19:29:58 2013
@@ -17,9 +17,9 @@ specific language governing permissions 
 under the License. 
 --> 
 <html>
-<title>Release Notes for Apache OpenJPA 2.2.0</title>
+<title>Release Notes for Apache OpenJPA 2.3.0</title>
 <body>
-<h1>Release Notes for Apache OpenJPA 2.2.0</h1>
+<h1>Release Notes for Apache OpenJPA 2.3.0</h1>
 <p>
 <ul>
   <li><a href="#Overview">Overview</a></li>
@@ -38,7 +38,7 @@ under the License. 
 
 <P>
    The Apache OpenJPA community is proud to release a distribution of
-   OpenJPA 2.2.0. This distribution is based on the final JSR 317 Java
+   OpenJPA 2.3.0. This distribution is based on the final JSR 317 Java
    Persistence API, Version 2.0 specification and passes the JPA 2.0 TCK,
    while remaining backwards compatible with prior releases based on the
    Java Persistence API (JPA 1.0) part of Java Community Process JSR-220
@@ -127,326 +127,315 @@ in each release of OpenJPA.</P>
 <h2><a name="ReleaseNotes">Release Notes</h2>
 
 <hr>
-<h3><a name="220">OpenJPA 2.2.0</h3>
+<h3><a name="220">OpenJPA 2.3.0</h3>
+
+        Release Notes - OpenJPA - Version 2.3.0
 
-        Release Notes - OpenJPA - Version 2.2.0
-    
 <h2>        Sub-task
 </h2>
 <ul>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1593'>OPENJPA-1593</a>] -         Create an OSGiManagedRuntime
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2081'>OPENJPA-2081</a>] -         Provide subset of XML support for OpenJPA annotations
-</li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2168'>OPENJPA-2168</a>] -         Do not go through LifeCycleEventManager overhead if the Entity has declared to be excluded
+    </li>
 </ul>
-            
+
 <h2>        Bug
 </h2>
 <ul>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-478'>OPENJPA-478</a>] -         Contradictory text in manual section 10.2.6. JPQL GROUP BY, HAVING
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-867'>OPENJPA-867</a>] -         Unexpected Behaviour of DBDictionary.indexOf() method
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1343'>OPENJPA-1343</a>] -         Incorrect example of openjpa.Sequence property
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1376'>OPENJPA-1376</a>] -         @SequenceGenerator allocationSize incorrect implementation
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1650'>OPENJPA-1650</a>] -         Adding a slice dynamically should be done via persistence unit only
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1651'>OPENJPA-1651</a>] -         Unique colums automatically defined as non-nullable (part 2)
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1657'>OPENJPA-1657</a>] -         Postgres connection throws NPE with null properties
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1686'>OPENJPA-1686</a>] -         Persistence of Dynamic and Generic Type
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1725'>OPENJPA-1725</a>] -         Schemaname wrongly included in DBDictionary.checkNameLength after Tablename correctly truncated
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1746'>OPENJPA-1746</a>] -         NullPointerException when a null value is set in the properties map passed to Entity.createEntityManagerFactory
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1768'>OPENJPA-1768</a>] -         StackOverflowError when finding an Entity with an Eager ManyToMany relationship.
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1787'>OPENJPA-1787</a>] -         Bean validation fails merging a new entity
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1845'>OPENJPA-1845</a>] -         the prepared query cache doesn&#39;t currently work correclty with &#39;SELECT IN&#39; statements
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1856'>OPENJPA-1856</a>] -         Executing bulk updates should evict stale data from the DataCache
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1873'>OPENJPA-1873</a>] -         EntityManager#merge sometimes passes wrong entity values to @PostLoad EntityListeners 
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1876'>OPENJPA-1876</a>] -         Slow JDBC tests
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1896'>OPENJPA-1896</a>] -         OpenJPA cannot store POJOs if a corresponding record already exists
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1898'>OPENJPA-1898</a>] -         TestQueryMultiThreaded fails with OOME &quot;unable to create new native thread&quot;
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1900'>OPENJPA-1900</a>] -         ClassCastException when serializing an entity if DetachedStateField=true
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1901'>OPENJPA-1901</a>] -         QueryCacheStoreQuery$CachedObjectId that is not Serializable
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1902'>OPENJPA-1902</a>] -         SQLServer reserved words may not be used as identifiers
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1903'>OPENJPA-1903</a>] -         Some queries only work the first time they are executed
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1904'>OPENJPA-1904</a>] -         OptimisticLockException during refresh(*,PESSIMISTIC_*) with eagar fetch on relationship fields
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1905'>OPENJPA-1905</a>] -         jar-file validation should be deferred until after OpenJPA is confirmed to be the application&#39;s chosen provider
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1906'>OPENJPA-1906</a>] -         Issue info / warning message when connection retain mode is always
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1909'>OPENJPA-1909</a>] -         enhance unit tests with the correct persistence.xml
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1910'>OPENJPA-1910</a>] -         openjpa uses application ClassLoader for resolving BrokerFactory (revisited)
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1911'>OPENJPA-1911</a>] -         InvalidStateException is thrown when merge an entity with derived identiy
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1912'>OPENJPA-1912</a>] -         enhancer generates invalid code if fetch-groups is activated
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1915'>OPENJPA-1915</a>] -         missing license header
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1918'>OPENJPA-1918</a>] -         MetaDataRepository.preload() ignores class loader returned by PersistenceUnitInfo.getClassLoader()
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1923'>OPENJPA-1923</a>] -         Allow flexible (non-standard) syntax for collection-valued parameters in IN() expresseion of  JPQL query
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1928'>OPENJPA-1928</a>] -         Resolving factory method does not allow method overriding
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1932'>OPENJPA-1932</a>] -         Documentation corrections
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1935'>OPENJPA-1935</a>] -         Informix lock exceptions are not mapped properly by OpenJPA
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1938'>OPENJPA-1938</a>] -         Typo of time data type in SQLServerdictionary for MSSQL 2008
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1939'>OPENJPA-1939</a>] -         index identifier max length for DB2 v9 is 128. 
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1940'>OPENJPA-1940</a>] -         ReverseMapping tool does not find primary keys with Oracle
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1941'>OPENJPA-1941</a>] -         Criteria query returns wrong result when query cache is enabled
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1943'>OPENJPA-1943</a>] -         Query timeout hint not honored consistently when pessimistic lock is issued to database requires multi-statements locking scheme
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1944'>OPENJPA-1944</a>] -         Extra select statements executed when version column is null. 
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1951'>OPENJPA-1951</a>] -         missing key &quot;cant-set-value&quot; in localizer properties org.apache.openjpa.jdbc.meta.strats
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1953'>OPENJPA-1953</a>] -         Copying data from inputStream to OuputStream needs appropriate buffer size
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1954'>OPENJPA-1954</a>] -         ArrayIndexOutOfBoundsException when querying on a version field that is in a MappedSuperclass
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1957'>OPENJPA-1957</a>] -         XML overriding column names for ArrayList attributes causes exception.
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1958'>OPENJPA-1958</a>] -         IndexOutOfBoundsException in BatchingPreparedStatementManagerImpl
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1959'>OPENJPA-1959</a>] -         RuntimeExceptionTranslator should be transient in DelegatingQuery
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1960'>OPENJPA-1960</a>] -         openjpa.InitializeEagerly breaks bean-validation integration
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1965'>OPENJPA-1965</a>] -         ClassCastException when using JAXB and MetaModel annotation processor
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1968'>OPENJPA-1968</a>] -         SQLServerDictionery not using DATETIME2 for jdbc driver other than MS JDBC driver
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1969'>OPENJPA-1969</a>] -         SQLServer / DataDirect SQLCode=HYT00 not handled
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1974'>OPENJPA-1974</a>] -         StackOverflowError when performing multiple subquery in collection field with eager fetch
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1975'>OPENJPA-1975</a>] -         Only obtain default schema name when needed (DB2)
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1981'>OPENJPA-1981</a>] -         Improper cleanup in SchemaGenerator
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1983'>OPENJPA-1983</a>] -         Merge of lazily fetched fields, and merge of managed entities deviates from spec
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1984'>OPENJPA-1984</a>] -         Incorrect ViolationContraint getRootBean when removing bean with embedded entity validation
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1985'>OPENJPA-1985</a>] -         ClassCastException in max(Timestamp) function on PostgreSQL
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1986'>OPENJPA-1986</a>] -         Extra queries being generated when cascading a persist
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1987'>OPENJPA-1987</a>] -         Postgres / Ingres does not support null table for getImportedKeys
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1989'>OPENJPA-1989</a>] -         *ToOne relationships specified as LAZY in xml aren&#39;t honored
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1992'>OPENJPA-1992</a>] -         java.lang.ArrayIndexOutOfBoundsException if positional parameter are not started from 1
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1994'>OPENJPA-1994</a>] -         Index is a reserved word for MySQL 
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1996'>OPENJPA-1996</a>] -         OpenJPA Samples fail on MacOS X
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1998'>OPENJPA-1998</a>] -         NPE getTableNameForMetadata when running SchemaTool reflect against Postgres DB
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2000'>OPENJPA-2000</a>] -         Wrong PostgreSQL data type for REAL - &quot;float8&quot;, must be &quot;float4&quot;
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2005'>OPENJPA-2005</a>] -         PostgresDictionary.isOwnedSequence needs a null check
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2006'>OPENJPA-2006</a>] -         Sequence generated ids may fail to get assigned when flushing a graph with bi-directional relationships
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2007'>OPENJPA-2007</a>] -         Setting query hint &quot;openjpa.FetchPlan.Isolation&quot; results in misleading warning
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2008'>OPENJPA-2008</a>] -         OpenJPA does not work with native queries in a distributed (Slice) environment
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2010'>OPENJPA-2010</a>] -         Duplicate meta data warning logged due to parsing the same location twice
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2011'>OPENJPA-2011</a>] -         Prevent reparsing annotation metadata for queries
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2013'>OPENJPA-2013</a>] -         columnDefinition for TEXT types ends up in wrong sql statement
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2025'>OPENJPA-2025</a>] -         Byte[] and Char[] should be treated as SingularAttributes, not lists by the metamodel generator
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2027'>OPENJPA-2027</a>] -         Metamodel genereated at runtime expects ListAttribute for all arrays - not just PersistentCollections. 
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2034'>OPENJPA-2034</a>] -         Update H2 Database sql error codes as per the changes in v1.3.154
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2036'>OPENJPA-2036</a>] -         DynamicEnhancer should look for tools.jar in java.home/lib for all JDKs, not just the IBM SDK.
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2039'>OPENJPA-2039</a>] -         FKs for EAGER fields that are not in the current fetchplan aren&#39;t selected
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2044'>OPENJPA-2044</a>] -         Invalid header in MetaModel classes generated by AnnotationProcessor
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2045'>OPENJPA-2045</a>] -         NAME is a valid column name for H2 databases.
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2051'>OPENJPA-2051</a>] -         Entities in a relationship are not properly cascaded after a EntityManager.flush is executed.
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2056'>OPENJPA-2056</a>] -         Postgres V9.1 issue with LIKE clause and Escape Strings
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2059'>OPENJPA-2059</a>] -         Missing localizer.properties for org.apache.openjpa.persistence.util.SourceCode
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2060'>OPENJPA-2060</a>] -         AnnotationProcess failed to generate metadata for List&lt;String&gt;[] attribute in entity
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2065'>OPENJPA-2065</a>] -         JPA 2.0 Spec. Violation? EntityManager#createNamedQuery(String, Class) bombs with non-entity Class parameter
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2066'>OPENJPA-2066</a>] -         Edge case in openJPA-1227. openJPA fails to create a join and thus returns wrong data when a collection is selected from superclass and another field is selected from subclass twoor more levels down the hierarchy.
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2069'>OPENJPA-2069</a>] -         Natvie sequence problems uncovered after OPENJPA-1376
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2070'>OPENJPA-2070</a>] -         Error processing while populating Metamodel classes needs improvement
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2071'>OPENJPA-2071</a>] -         NPE during ResultPacker interface processing
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2073'>OPENJPA-2073</a>] -         MappingTools requires live connection to DB2 server to retrieve default schema name
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2076'>OPENJPA-2076</a>] -         Minor fix-ups to messages
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2077'>OPENJPA-2077</a>] -         Pom references to org.codehaus.mojo openjpa-maven-plugin cause problems
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2083'>OPENJPA-2083</a>] -         Unmapped fields silently treated as transient
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2100'>OPENJPA-2100</a>] -         openjpa-maven-plugin fails to create SQL for entities which contain enums
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2101'>OPENJPA-2101</a>] -         PersistenceProductDerivation overwrites the RemoteCommitProvider configuration
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2104'>OPENJPA-2104</a>] -         BindParameter is not a valid query parameter as processed in DBDictionary&#39;s setUnknown()
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2105'>OPENJPA-2105</a>] -         Document changes no longer being uploaded
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2107'>OPENJPA-2107</a>] -         ManagedCache conflict due adding an entity 2 times in the same query.
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2117'>OPENJPA-2117</a>] -         XML overriding column names for 1xM attributes causes exception.
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2119'>OPENJPA-2119</a>] -         Update org.apache.openjpa.persistence.util.SourceCode
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2122'>OPENJPA-2122</a>] -         VerifyError with Java 7 when using javaagent or dynamic container enhancement
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2124'>OPENJPA-2124</a>] -         Use of XMLValueHandler results in a NullPointerException when classloader does not provide package support
-</li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-696'>OPENJPA-696</a>] -         Cache TransactionSynchronizationRegistry per EMF (vs JVM)
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1794'>OPENJPA-1794</a>] -         Result of aggregate function MAX is 0 on empty table (instead of NULL).
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1819'>OPENJPA-1819</a>] -         ORDER BY will append additional column to the SELECT clause which may potentialy cause ORA-00979 error
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1901'>OPENJPA-1901</a>] -         QueryCacheStoreQuery$CachedObjectId that is not Serializable
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1979'>OPENJPA-1979</a>] -         Regression for non-standard joins with constant column values
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1993'>OPENJPA-1993</a>] -         Deadlock Potential with ORM XML Processing
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2018'>OPENJPA-2018</a>] -         Cannot bind String[] to ParameterExpression for path.in(parameter)
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2067'>OPENJPA-2067</a>] -         A &#39;length&#39; of &#39;-1&#39; passed to PreparedStatement.setBinaryStream can cause an exception on some, but not all, JDBC drivers.
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2072'>OPENJPA-2072</a>] -         InvalidStateException deleting an instance with a timestamp in its primary key
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2095'>OPENJPA-2095</a>] -         Unhandled exception thrown from within an Externalizer method causes incorrect/incomplete SQL to be generated/executed.
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2102'>OPENJPA-2102</a>] -         URLs which contains spaces are not properly handled by OpenJPA.
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2110'>OPENJPA-2110</a>] -         Abstract entity causes standard openjpa collection proxies to be injected even if custom collections are used.
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2118'>OPENJPA-2118</a>] -         Prepared SQL query does not handle collection-valued parameter where collection is empty
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2123'>OPENJPA-2123</a>] -         Minor performance improvements for Connection and ResultSet processing
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2131'>OPENJPA-2131</a>] -         Missing IN or OUT parameter exception with OracleDictionary
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2132'>OPENJPA-2132</a>] -         Traversal of a OneToMany relationship returns an empty list when InheritanceType.JOINED or SINGLE_TABLE is used.
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2133'>OPENJPA-2133</a>] -         OpenJPA doesn&#39;t find custom mappings with an applicable class loader
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2136'>OPENJPA-2136</a>] -         NPE when using LiteAutoDetach
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2140'>OPENJPA-2140</a>] -         Locking tests issue many warnings about the use of a duplicate pu name
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2142'>OPENJPA-2142</a>] -         Merge of a new object does not handle Entity Id field
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2145'>OPENJPA-2145</a>] -         Missing ASM depending jar in binary zip
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2146'>OPENJPA-2146</a>] -         StateManager for Embeddable may throw Exception while initializing
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2149'>OPENJPA-2149</a>] -         Criteria.function adds wrong casts to parameters making it unsuable
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2153'>OPENJPA-2153</a>] -         NoSuchMethodException of DBCPDriverDataSource.newInstance()
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2154'>OPENJPA-2154</a>] -         test-dynamic-enhancer profile failed for module more than one level deep
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2156'>OPENJPA-2156</a>] -         Fix bug in org.apache.openjpa.persistence.util.SourceCode to correctly generate imports.
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2158'>OPENJPA-2158</a>] -         LiteAutoDetach + DetachProxyFields=false can lead to Broker concurrency exceptions
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2161'>OPENJPA-2161</a>] -         Make some members of StateManagerImpl protected to allow for greater extensability
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2163'>OPENJPA-2163</a>] -         Lifecycle event callback occurs more often than expect
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2170'>OPENJPA-2170</a>] -         Multiple INSERT of the same row in batch update manager
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2172'>OPENJPA-2172</a>] -         openjpa-all jar is missing slf4j runtime dependency
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2174'>OPENJPA-2174</a>] -         Result set mapping was not looked up when retrieving column data from a NamedNativeQuery
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2178'>OPENJPA-2178</a>] -         PostgresDictionary
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2180'>OPENJPA-2180</a>] -         OpenJPA build broken in java7 / jdk-1.7
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2187'>OPENJPA-2187</a>] -         metamodel generation with default package creates invalid class
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2191'>OPENJPA-2191</a>] -         QueryCache don&#39;t allow for misconfigurations
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2196'>OPENJPA-2196</a>] -         Create Sequence Postgres 9.1
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2197'>OPENJPA-2197</a>] -         MethodComparator in AnnotationPersistenceMetaDataParser should also compare parameters
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2199'>OPENJPA-2199</a>] -         Constraint violation exception when removing relationship using (orphanRemoval = true)
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2204'>OPENJPA-2204</a>] -         NPE in JDBCStoreManager with Trace turned on
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2221'>OPENJPA-2221</a>] -         Use of AbstractValueHandler map() causes exception on find()
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2227'>OPENJPA-2227</a>] -         OpenJPA doesn&#39;t find custom SequenceGenerators
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2228'>OPENJPA-2228</a>] -         QuerySQLCache broken for Entities with @EmbeddedId
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2229'>OPENJPA-2229</a>] -         Persistence entities not recognized when deploying on JBoss AS 7.1
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2230'>OPENJPA-2230</a>] -         Event Listener detection didn&#39;t work with MappedSuperClasses or Entity heirarchies
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2234'>OPENJPA-2234</a>] -         EntityManager instance creation needs TX activity
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2235'>OPENJPA-2235</a>] -         &quot;READ_UNCOMMITTED&quot; setting for the fetch plan isolation level is ignored in DB2Dictionary
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2236'>OPENJPA-2236</a>] -         Trace of connection info can cause class transform/enhancement to fail
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2238'>OPENJPA-2238</a>] -         IllegalAccessError when trying to proxy a default scoped Class
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2240'>OPENJPA-2240</a>] -         JVMVRFY012 when using openjpa together with hyperjaxb3
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2244'>OPENJPA-2244</a>] -         Nested classpath ignored in mapping tool ant task
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2245'>OPENJPA-2245</a>] -         NotSerializableException when using a remote QueryCache and the Criteria API
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2247'>OPENJPA-2247</a>] -         JoinColumn annotation is ignored when mapping a unidirectional owned OneToOne that is in a SecondaryTable
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2253'>OPENJPA-2253</a>] -         Memory leak in Audit feature
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2255'>OPENJPA-2255</a>] -         Couldn&#39;t load the referencedColumn definition when create the JoinTable
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2257'>OPENJPA-2257</a>] -         Concurreny in org.apache.openjpa.persistence.EntityManagerImpl.getProperties leads to NullPointer and ConcurrentModificationException
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2260'>OPENJPA-2260</a>] -         Parenthesis-augmented parameters are improperly processed at EM level
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2261'>OPENJPA-2261</a>] -         Query SQL Cache issue with NULL parameters
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2267'>OPENJPA-2267</a>] -         native query select with null result causes NullPointerException
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2269'>OPENJPA-2269</a>] -         Duplicate key exception in sequence table on multithreaded initialization
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2271'>OPENJPA-2271</a>] -         Old &lt;ciManagement/&gt; info on root POM
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2282'>OPENJPA-2282</a>] -         ESCAPE &#39;\&#39; is appended to the like clause unexpectedly
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2284'>OPENJPA-2284</a>] -         NPE occurs when &lt;cascade-persist/&gt; is added to a &lt;persistence-unit-defaults&gt; in an orm.
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2288'>OPENJPA-2288</a>] -         MetaDataRepository should be able to filter classes from other app ClassLoaders in JEE Env
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2289'>OPENJPA-2289</a>] -         Additional SQL alias generated for query with subquery causes incorrect # of rows returned - Oracle only
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2298'>OPENJPA-2298</a>] -         VerifyError/Stack underflow due to extra &#39;return&#39; statements generated by PCEnhancer.
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2304'>OPENJPA-2304</a>] -         Thread deadlock in CriteriaBuilder
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2305'>OPENJPA-2305</a>] -         Canonical MetaModel class generation should not use inhertence
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2318'>OPENJPA-2318</a>] -         Left outer join is not generated when specifien using Criteria API
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2320'>OPENJPA-2320</a>] -         CriteriaBuilder predicate construction deadlocks in multi-core VM due to static initializer
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2321'>OPENJPA-2321</a>] -         Synchronizing logging output stream causes deadlock when used some JDK LogManger derivative
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2325'>OPENJPA-2325</a>] -         MappedSuperClass without an @Id causes wrong identity type for the inherited types
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2326'>OPENJPA-2326</a>] -         Updates in TCK execution configuration
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2328'>OPENJPA-2328</a>] -         NPE caused by one too many calls on the iterator inside the library.
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2330'>OPENJPA-2330</a>] -         Stackoverflow due to endless recursive calls
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2334'>OPENJPA-2334</a>] -         OpenJPA must support processing puRoot &amp; jar-file URLs as jar-formatted InputStreams
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2335'>OPENJPA-2335</a>] -         Constrained foreign key column value setting needs to be flexible
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2336'>OPENJPA-2336</a>] -         Relax Join column name comparison based on database dictionary schema case setting
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2343'>OPENJPA-2343</a>] -         Version field returns null when explicity projected from a JOIN in SELECT clause
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2355'>OPENJPA-2355</a>] -         CONCAT() function must support more than two arguments
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2357'>OPENJPA-2357</a>] -         @..ToMany(optional=false) throws InvalidStateException: [...] the metadata for this field specifies that nulls are illegal.
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2377'>OPENJPA-2377</a>] -         Metamodel.managedType returns wrong result for Embeddable
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2378'>OPENJPA-2378</a>] -         TestHandlerStrategy.testIssue_OPENJPA2328 failed with Oracle
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2384'>OPENJPA-2384</a>] -         Rendering criteria query to JPQL-like string ignores multiple GROUP BY clauses
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2390'>OPENJPA-2390</a>] -         HSQLDB SELECT NEXT VALUE FOR Sequence will skip 1 sequence value if allocation size is 1
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2391'>OPENJPA-2391</a>] -         HSQLDB v2.2.9
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2400'>OPENJPA-2400</a>] -         Support MariaDB
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2405'>OPENJPA-2405</a>] -         EntityManager.merge does not work for entity that is managed by another EntityManager
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2409'>OPENJPA-2409</a>] -         allow the openjpa-maven-plugin to use a persistence.xml from resources and not only from files
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2414'>OPENJPA-2414</a>] -         FinderCache does not consider active Fetch Groups/FetchPlan added Fields
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2418'>OPENJPA-2418</a>] -         Cannot build 2.2.x due to NullPointerException in maven-checkstyle-plugin
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2421'>OPENJPA-2421</a>] -         Slices: Can&#39;t setting up FinderTargetPolicy
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2425'>OPENJPA-2425</a>] -         SELECT fields with @ExternalValues defined returns datastore values instead of unmapped fields
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2432'>OPENJPA-2432</a>] -         MySQL dictionary can&#39;t be found from a valid connection
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2435'>OPENJPA-2435</a>] -         Version field in a projection always returned as an Integer.
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2437'>OPENJPA-2437</a>] -         transactional listeners added too late to observe begin event
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2440'>OPENJPA-2440</a>] -         foreign key drop leaks jdbc connections
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2443'>OPENJPA-2443</a>] -         InvalidStateException while merging a new Entity with a GeneratedValue id
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2444'>OPENJPA-2444</a>] -         ReverseMappingTool creates orm.xml files in the current working directory
+    </li>
 </ul>
-            
+
 <h2>        Improvement
 </h2>
 <ul>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-302'>OPENJPA-302</a>] -         PCEnhancer needs target classes on classpath
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-487'>OPENJPA-487</a>] -         Generated SUBSTRING SQL is ugly and inefficient
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-758'>OPENJPA-758</a>] -         OpenJPA doesn&#39;t find ValueHandlers with an applicable class loader
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1555'>OPENJPA-1555</a>] -         SQLBuffer code cleanup
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1777'>OPENJPA-1777</a>] -         Allow setting of diagonstic context for each slice in a more flexible manner
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1778'>OPENJPA-1778</a>] -         Improved error information for unenhanced classes. 
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1798'>OPENJPA-1798</a>] -         Improve messages in localize.properties
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1803'>OPENJPA-1803</a>] -         Unwrap EntityManager to Connection
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1847'>OPENJPA-1847</a>] -         Use a single connection when generating schema
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1863'>OPENJPA-1863</a>] -         update HSQL dictionary for HSQLDB 2.0
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1917'>OPENJPA-1917</a>] -         Cache column alias in SelectImpl
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1937'>OPENJPA-1937</a>] -         Document OpenJPAEntityManager.evict methods
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1945'>OPENJPA-1945</a>] -         Improve aspects of the OpenBooks sample
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1972'>OPENJPA-1972</a>] -         DB2 V9.7 changed the default behavior concerning blocking behavior with isolation levels greater then read uncommitted
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1990'>OPENJPA-1990</a>] -         Skip getting extend exception text when running on DB2
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1999'>OPENJPA-1999</a>] -         Optional support for non-sequential positional parameters
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2014'>OPENJPA-2014</a>] -         Allow proxies to stay in place when Detaching
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2020'>OPENJPA-2020</a>] -         Make some members of StateManagerImpl protected to allow for greater extensability
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2031'>OPENJPA-2031</a>] -         Unable to import maven projects with m2e version 1.0
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2042'>OPENJPA-2042</a>] -         Diagnostics for Application Managed EntityManagerFactory leaks.
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2043'>OPENJPA-2043</a>] -         OpenJPAId hashCode() value needs to be consistent after serialization process
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2047'>OPENJPA-2047</a>] -         Document the impact of Persistence Aware classes
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2068'>OPENJPA-2068</a>] -         Improve performance of java.util.Calendar fields
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2075'>OPENJPA-2075</a>] -         Abstract out parameter handling / validation from org.apache.openjpa.persistence.QueryImpl to allow for greater extensibility
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2084'>OPENJPA-2084</a>] -         Upgrade Derby dependency to 10.8.x
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2085'>OPENJPA-2085</a>] -         Improve enhancement process to support JAVA 7 compliant class file generation
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2087'>OPENJPA-2087</a>] -         Remove or limit the use of the ConcreteClassGenerator
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2116'>OPENJPA-2116</a>] -         Scrape the barrel for performance juice
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2120'>OPENJPA-2120</a>] -         Add new option to eliminate reflection calls from enhancer generated IdClass PC copy operations
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2128'>OPENJPA-2128</a>] -         Add a boolean to FieldMetaData to denote whether or not a field has a @EmbeddedId annotation.
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2130'>OPENJPA-2130</a>] -         Enable Java 7 testing by allowing test cases to compile targeting to 1.7  
-</li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2120'>OPENJPA-2120</a>] -         Add new option to eliminate reflection calls from enhancer generated IdClass PC copy operations
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2134'>OPENJPA-2134</a>] -         Do not close Connections when ConnectionRetainMode is set to &quot;always&quot;
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2137'>OPENJPA-2137</a>] -         Make some members of StateManagerImpl protected to allow for greater extensibility
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2143'>OPENJPA-2143</a>] -         Reduce lock contention on LifecycleEventManager
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2151'>OPENJPA-2151</a>] -         Improve the performance of StateManagerImpl.initialize
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2152'>OPENJPA-2152</a>] -         Don&#39;t process query hints when LockModeType == NONE
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2159'>OPENJPA-2159</a>] -         Add support for no rounding of Date
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2162'>OPENJPA-2162</a>] -         Avoid delimited identifier processing if it&#39;s not required by application
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2164'>OPENJPA-2164</a>] -         Don&#39;t setPCState if field requested is already loaded
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2167'>OPENJPA-2167</a>] -         Misc changes to improve flush() path performance
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2171'>OPENJPA-2171</a>] -         asm should be optional
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2189'>OPENJPA-2189</a>] -         Update OpenBooks example to build, install, and execute in the WAS Liberty Profile
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2208'>OPENJPA-2208</a>] -         Add additional Java 2 Security doPriv function
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2209'>OPENJPA-2209</a>] -         MetaDataRepository preload configuration should be more inclusive
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2220'>OPENJPA-2220</a>] -         Persistent field fetching statistic tool
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2231'>OPENJPA-2231</a>] -         jest  TokenReplacedStream use Reader instead of Inputstream
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2264'>OPENJPA-2264</a>] -         Upcast PreparedStatementManagerImpl.logSQLWarnings to take a Statement rather than a PreparedStatement
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2275'>OPENJPA-2275</a>] -         Extending SchemaTool
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2292'>OPENJPA-2292</a>] -         Reduce object allocations
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2293'>OPENJPA-2293</a>] -         Reduce LifecycleEventManager
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2324'>OPENJPA-2324</a>] -         Option to express literal in query string directly into generate SQL
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2332'>OPENJPA-2332</a>] -         Update message when unable to resolve datasource configuration
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2342'>OPENJPA-2342</a>] -         Consider modifying PCEnhancer.run to use serp.bytecode.BCClass.getDeclaredInterfaceNames instead of getDeclaredInterfaceTypes.
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2346'>OPENJPA-2346</a>] -         Optimize MetaDataRepository.getMetaDataInternal
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2347'>OPENJPA-2347</a>] -         Make StateManagerImpl more extensible
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2348'>OPENJPA-2348</a>] -         Cache calculated hashCode in OpenJPAId
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2353'>OPENJPA-2353</a>] -         Reduce object allocations
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2354'>OPENJPA-2354</a>] -         Removed synchronized from enhancer added pcReplaceStateManager method
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2368'>OPENJPA-2368</a>] -         Move www.apache.org/openjpa/ns/orm to openjpa.apache.org/ns/orm
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2410'>OPENJPA-2410</a>] -         Build time detection of System.out/err.print(ln) in source files
+    </li>
 </ul>
-    
+
 <h2>        New Feature
 </h2>
 <ul>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-184'>OPENJPA-184</a>] -         use DB2 Diagnostic interface to report extended error diagnostics on SQL Exception
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1859'>OPENJPA-1859</a>] -         Create a sample to demonstrate usage of JEST
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1934'>OPENJPA-1934</a>] -         contribute an openjpa-maven-plugin 
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2108'>OPENJPA-2108</a>] -         Allow an option to terminate MappingTool-generated SQL with a character other than semicolon   
-</li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2283'>OPENJPA-2283</a>] -         Upgrade to ASM 4 dependency
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2295'>OPENJPA-2295</a>] -         speed up query metadata lookup
+    </li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2366'>OPENJPA-2366</a>] -         provide option to exclude schema name from generated @Table annotation for generated entities
+    </li>
+</ul>
+
+<h2>        Question
+</h2>
+<ul>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1532'>OPENJPA-1532</a>] -         Should the &lt;shared-cache-mode&gt; element in a persistence unit definition automatically turn on the data cache?
+    </li>
 </ul>
-                            
+
 <h2>        Task
 </h2>
 <ul>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1786'>OPENJPA-1786</a>] -         Upgrade to latest JPA 2.0 TCK
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1834'>OPENJPA-1834</a>] -         Upgrade trunk to use Deby 10.6.2.1 for junits
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-1875'>OPENJPA-1875</a>] -         Add generics to the Graph code
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2089'>OPENJPA-2089</a>] -         upgrade bval to latest 0.3-incubating
-</li>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2091'>OPENJPA-2091</a>] -         update docbook maven plugin
-</li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2388'>OPENJPA-2388</a>] -         support new xbean asm4 shade
+    </li>
 </ul>
-        
+
 <h2>        Test
 </h2>
 <ul>
-<li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2029'>OPENJPA-2029</a>] -         Add PreparedQuery tests for non-sequential positional parameters support
-</li>
+    <li>[<a href='https://issues.apache.org/jira/browse/OPENJPA-2169'>OPENJPA-2169</a>] -         TestOracleXmlColumn test failed using Oracle 11.2 driver
+    </li>
 </ul>
 
 <BR>
@@ -454,6 +443,9 @@ in each release of OpenJPA.</P>
 <h2><a name="Previous"></a>Previous Releases</h2>
 <p>Release notes for earlier releases of OpenJPA may be found in SVN at the following locations. 
 <ul>
+  <li><a href='http://svn.apache.org/viewvc/openjpa/tags/2.2.2/openjpa-project/RELEASE-NOTES.html?view=co'>OpenJPA 2.2.2 RELEASE-NOTES.html</a></li>
+  <li><a href='http://svn.apache.org/viewvc/openjpa/tags/2.2.1/openjpa-project/RELEASE-NOTES.html?view=co'>OpenJPA 2.2.1 RELEASE-NOTES.html</a></li>
+  <li><a href='http://svn.apache.org/viewvc/openjpa/tags/2.2.0/openjpa-project/RELEASE-NOTES.html?view=co'>OpenJPA 2.2.0 RELEASE-NOTES.html</a></li>
   <li><a href='http://svn.apache.org/viewvc/openjpa/tags/2.1.1/openjpa-project/RELEASE-NOTES.html?view=co'>OpenJPA 2.1.1 RELEASE-NOTES.html</a></li>
   <li><a href='http://svn.apache.org/viewvc/openjpa/tags/2.1.0/openjpa-project/RELEASE-NOTES.html?view=co'>OpenJPA 2.1.0 RELEASE-NOTES.html</a></li>
   <li><a href='http://svn.apache.org/viewvc/openjpa/tags/2.0.1/openjpa-project/RELEASE-NOTES.html?view=co'>OpenJPA 2.0.1 RELEASE-NOTES.html</a></li>