Serialized Form
-
Package org.apache.openjpa.abstractstore
-
Class org.apache.openjpa.abstractstore.AbstractStoreBrokerFactory extends AbstractBrokerFactory implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.openjpa.conf
-
Class org.apache.openjpa.conf.CallbackOptions extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_allowsDuplicateListener
boolean _allowsDuplicateListener
-
_allowsMultipleMethodsForSameCallback
boolean _allowsMultipleMethodsForSameCallback
-
_isPostPersistCallbackImmediate
boolean _isPostPersistCallbackImmediate
-
-
Class org.apache.openjpa.conf.OpenJPAConfigurationImpl extends ConfigurationImpl implements Serializable
-
Serialization Methods
-
readExternal
public void readExternal(ObjectInput arg0) throws IOException, ClassNotFoundException
- Throws:
IOException
ClassNotFoundException
-
writeExternal
public void writeExternal(ObjectOutput arg0) throws IOException
- Throws:
IOException
-
-
-
-
Package org.apache.openjpa.datacache
-
Class org.apache.openjpa.datacache.AbstractDataCache extends AbstractConcurrentEventManager implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_closed
boolean _closed
-
_evictOnBulkUpdate
boolean _evictOnBulkUpdate
-
_excludedTypes
Set<String> _excludedTypes
-
_includedTypes
Set<String> _includedTypes
-
_name
String _name
-
_schedule
String _schedule
-
_stats
CacheStatisticsSPI _stats
-
conf
OpenJPAConfiguration conf
The configuration set by the system. -
log
Log log
The log to use.
-
-
Class org.apache.openjpa.datacache.AbstractQueryCache extends AbstractConcurrentEventManager implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_closed
boolean _closed
-
_name
String _name
-
_stats
QueryStatistics<QueryKey> _stats
-
_statsEnabled
boolean _statsEnabled
-
conf
OpenJPAConfiguration conf
The configuration set by the system. -
entityTimestampMap
ConcurrentHashMap<String,Long> entityTimestampMap
-
evictPolicy
AbstractQueryCache.EvictPolicy evictPolicy
-
log
Log log
The log to use.
-
-
Class org.apache.openjpa.datacache.AbstractQueryCache.Default extends Object implements Serializable
- serialVersionUID:
- -7889619105916307055L
-
Class org.apache.openjpa.datacache.CacheStatisticsImpl extends Object implements Serializable
- serialVersionUID:
- 9014495759588003166L
-
Class org.apache.openjpa.datacache.ConcurrentDataCache extends AbstractDataCache implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_cache
CacheMap _cache
-
_cacheSize
int _cacheSize
-
_lru
boolean _lru
-
_softRefs
int _softRefs
-
-
Class org.apache.openjpa.datacache.ConcurrentQueryCache extends AbstractQueryCache implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_cache
CacheMap _cache
-
_cacheSize
int _cacheSize
-
_lru
boolean _lru
-
_softRefs
int _softRefs
-
-
Class org.apache.openjpa.datacache.DataCachePCDataImpl extends PCDataImpl implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_exp
long _exp
-
-
Class org.apache.openjpa.datacache.ExpirationEvent extends EventObject implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_expired
boolean _expired
-
_key
Object _key
-
-
Class org.apache.openjpa.datacache.PartitionedDataCache extends ConcurrentDataCache implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.datacache.QueryCacheStoreQuery extends Object implements Serializable
-
Serialization Methods
-
writeReplace
public Object writeReplace() throws ObjectStreamException
- Throws:
ObjectStreamException
-
-
Serialized Fields
-
_cache
QueryCache _cache
-
_query
StoreQuery _query
-
_repos
MetaDataRepository _repos
-
_sctx
StoreContext _sctx
-
-
-
Class org.apache.openjpa.datacache.QueryCacheStoreQuery.CachedList extends AbstractList<Object> implements Serializable
-
Serialization Methods
-
writeReplace
public Object writeReplace() throws ObjectStreamException
- Throws:
ObjectStreamException
-
-
Serialized Fields
-
_fc
FetchConfiguration _fc
-
_proj
boolean _proj
-
_res
QueryResult _res
-
_sctx
StoreContext _sctx
-
-
-
Class org.apache.openjpa.datacache.QueryKey extends Object implements Serializable
-
Serialization Methods
-
readExternal
public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException
- Throws:
IOException
ClassNotFoundException
-
writeExternal
public void writeExternal(ObjectOutput out) throws IOException
- Throws:
IOException
-
-
-
Class org.apache.openjpa.datacache.QueryResult extends ArrayList<Object> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_ex
long _ex
-
_timestamp
long _timestamp
-
-
Class org.apache.openjpa.datacache.TypesChangedEvent extends EventObject implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_types
Collection _types
-
-
-
Package org.apache.openjpa.enhance
-
Class org.apache.openjpa.enhance.ReflectingPersistenceCapable extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialization Methods
-
readObject
private void readObject(ObjectInputStream in) throws ClassNotFoundException, IOException
- Throws:
ClassNotFoundException
IOException
-
writeObject
private void writeObject(ObjectOutputStream out) throws IOException
- Throws:
IOException
-
-
Serialized Fields
-
o
Object o
-
serializationUserVisible
boolean serializationUserVisible
-
sm
StateManager sm
-
-
-
Package org.apache.openjpa.event
-
Class org.apache.openjpa.event.BeanLifecycleCallbacks extends MethodLifecycleCallbacks implements Serializable
-
Serialization Methods
-
readExternal
public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException
- Throws:
IOException
ClassNotFoundException
-
writeExternal
public void writeExternal(ObjectOutput out) throws IOException
- Throws:
IOException
-
-
-
Class org.apache.openjpa.event.BrokerFactoryEvent extends EventObject implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
eventType
int eventType
-
-
Class org.apache.openjpa.event.BrokerFactoryEventManager extends AbstractConcurrentEventManager implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_conf
Configuration _conf
-
-
Class org.apache.openjpa.event.LifecycleEvent extends EventObject implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_related
Object _related
-
_type
int _type
-
-
Class org.apache.openjpa.event.LifecycleEventManager extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_activated
boolean _activated
-
_addListeners
List<Object> _addListeners
-
_classListeners
Map<Class<?>,LifecycleEventManager.ListenerList> _classListeners
-
_exceps
List<Exception> _exceps
-
_fail
boolean _fail
-
_failFast
boolean _failFast
-
_firing
boolean _firing
-
_listeners
LifecycleEventManager.ListenerList _listeners
-
_remListeners
List<Object> _remListeners
-
-
Class org.apache.openjpa.event.LifecycleEventManager.ListenerList extends ArrayList<Object> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_types
int _types
-
-
Class org.apache.openjpa.event.MethodLifecycleCallbacks extends Object implements Serializable
-
Serialization Methods
-
readExternal
public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException
- Throws:
IOException
ClassNotFoundException
-
writeExternal
public void writeExternal(ObjectOutput out) throws IOException
- Throws:
IOException
-
-
-
Class org.apache.openjpa.event.RemoteCommitEvent extends Object implements Serializable
-
Serialization Methods
-
readExternal
public void readExternal(ObjectInput in) throws IOException
- Throws:
IOException
-
writeExternal
public void writeExternal(ObjectOutput out) throws IOException
- Throws:
IOException
-
-
-
Class org.apache.openjpa.event.RemoteCommitEventManager extends AbstractConcurrentEventManager implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_provider
RemoteCommitProvider _provider
-
_transmitPersIds
boolean _transmitPersIds
-
-
Class org.apache.openjpa.event.TransactionEvent extends EventObject implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_type
int _type
-
-
Class org.apache.openjpa.event.TransactionEventManager extends AbstractConcurrentEventManager implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_begin
int _begin
-
_end
int _end
-
_flush
int _flush
-
-
-
Package org.apache.openjpa.kernel
-
Class org.apache.openjpa.kernel.AbstractBrokerFactory extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialization Methods
-
readResolve
protected Object readResolve() throws ObjectStreamException
Replaces the factory with this JVMs pooled version if it exists. Also freezes the factory.- Throws:
ObjectStreamException
-
-
Serialized Fields
-
_conf
OpenJPAConfiguration _conf
-
_lock
ReentrantLock _lock
-
_poolKey
Object _poolKey
-
_userObjects
Map<Object,Object> _userObjects
-
-
Class org.apache.openjpa.kernel.AbstractPCData extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.kernel.AbstractStoreQuery extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
ctx
QueryContext ctx
-
-
Class org.apache.openjpa.kernel.BrokerImpl extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialization Methods
-
readObject
private void readObject(ObjectInputStream in) throws ClassNotFoundException, IOException
- Throws:
ClassNotFoundException
IOException
-
writeObject
private void writeObject(ObjectOutputStream out) throws IOException
- Throws:
IOException
-
-
Serialized Fields
-
_allowReferenceToSiblingContext
boolean _allowReferenceToSiblingContext
-
_autoClear
int _autoClear
-
_autoDetach
int _autoDetach
-
_cache
org.apache.openjpa.kernel.ManagedCache _cache
-
_cacheFinderQuery
boolean _cacheFinderQuery
-
_cachePreparedQuery
boolean _cachePreparedQuery
-
_connectionFactory2Name
String _connectionFactory2Name
-
_connectionFactoryName
String _connectionFactoryName
-
_connRetainMode
int _connRetainMode
-
_deletedClss
Set<Class<?>> _deletedClss
-
_derefAdditions
Set<StateManagerImpl> _derefAdditions
-
_derefCache
Set<StateManagerImpl> _derefCache
-
_detachedNew
boolean _detachedNew
-
_detachState
int _detachState
-
_evictDataCache
boolean _evictDataCache
-
_fc
FetchConfiguration _fc
-
_fcs
LinkedList<FetchConfiguration> _fcs
-
_flags
int _flags
-
_ignoreChanges
boolean _ignoreChanges
-
_largeTransaction
boolean _largeTransaction
-
_lifeCallbackMode
int _lifeCallbackMode
-
_lifeEventManager
LifecycleEventManager _lifeEventManager
-
_managed
boolean _managed
-
_multithreaded
boolean _multithreaded
-
_nontransRead
boolean _nontransRead
-
_nontransWrite
boolean _nontransWrite
-
_optimistic
boolean _optimistic
-
_orderDirty
boolean _orderDirty
-
_pass
String _pass
-
_pending
Set<StateManagerImpl> _pending
-
_persistedClss
Set<Class<?>> _persistedClss
-
_populateDataCache
boolean _populateDataCache
-
_postLoadOnMerge
boolean _postLoadOnMerge
-
_printParameters
boolean _printParameters
-
_restoreState
int _restoreState
-
_retainState
boolean _retainState
-
_savepointCache
Set<StateManagerImpl> _savepointCache
-
_savepoints
LinkedMap _savepoints
-
_suppressBatchOLELogging
boolean _suppressBatchOLELogging
-
_sync
jakarta.transaction.Synchronization _sync
-
_syncManaged
boolean _syncManaged
-
_transAdditions
Set<StateManagerImpl> _transAdditions
-
_transCache
org.apache.openjpa.kernel.BrokerImpl.TransactionalCache _transCache
-
_transCallbackMode
int _transCallbackMode
-
_transEventManager
TransactionEventManager _transEventManager
-
_updatedClss
Set<Class<?>> _updatedClss
-
_user
String _user
-
_userObjects
Map<Object,Object> _userObjects
-
findAllDepth
int findAllDepth
-
-
Class org.apache.openjpa.kernel.BrokerImpl.StateManagerId extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_bhash
int _bhash
-
_id
long _id
-
-
Class org.apache.openjpa.kernel.DelegatingBrokerFactory extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_del
DelegatingBrokerFactory _del
-
_factory
BrokerFactory _factory
-
_trans
RuntimeExceptionTranslator _trans
-
-
Class org.apache.openjpa.kernel.DelegatingFetchConfiguration extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_del
DelegatingFetchConfiguration _del
-
_fetch
FetchConfiguration _fetch
-
_trans
RuntimeExceptionTranslator _trans
-
-
Class org.apache.openjpa.kernel.DelegatingQuery extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_del
DelegatingQuery _del
-
_query
Query _query
-
-
Class org.apache.openjpa.kernel.DelegatingResultList extends Object implements Serializable
-
Serialization Methods
-
writeReplace
public Object writeReplace() throws ObjectStreamException
Writes delegate, which may in turn write a normal list.- Throws:
ObjectStreamException
-
-
Serialized Fields
-
_del
ResultList<T> _del
-
_trans
RuntimeExceptionTranslator _trans
-
-
-
Class org.apache.openjpa.kernel.DetachedStateManager extends org.apache.openjpa.kernel.AttachStrategy implements Serializable
- serialVersionUID:
- 4112223665584731100L
-
Serialized Fields
-
_access
boolean _access
-
_dirty
BitSet _dirty
-
_embedded
boolean _embedded
-
_loaded
BitSet _loaded
-
_lock
ReentrantLock _lock
-
_oid
Object _oid
-
_pc
PersistenceCapable _pc
-
_useDSFForUnproxy
boolean _useDSFForUnproxy
-
_version
Object _version
-
-
Class org.apache.openjpa.kernel.DistinctResultList extends Object implements Serializable
- serialVersionUID:
- -6140119764940777922L
-
Serialization Methods
-
writeReplace
public Object writeReplace() throws ObjectStreamException
- Throws:
ObjectStreamException
-
-
Serialized Fields
-
_del
ArrayList<E> _del
-
_trans
RuntimeExceptionTranslator _trans
-
-
Class org.apache.openjpa.kernel.ExpressionStoreQuery extends AbstractStoreQuery implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_parser
ExpressionParser _parser
-
-
Class org.apache.openjpa.kernel.ExpressionStoreQuery.DataStoreExecutor extends ExpressionStoreQuery.AbstractExpressionExecutor implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_exps
QueryExpressions[] _exps
-
_facts
ExpressionFactory[] _facts
-
_inMemOrdering
Value[] _inMemOrdering
-
_meta
ClassMetaData _meta
-
_metas
ClassMetaData[] _metas
-
_parser
ExpressionParser _parser
-
_projTypes
Class[] _projTypes
-
_subs
boolean _subs
-
-
Class org.apache.openjpa.kernel.ExpressionStoreQuery.InMemoryExecutor extends ExpressionStoreQuery.AbstractExpressionExecutor implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_exps
QueryExpressions[] _exps
-
_factory
InMemoryExpressionFactory _factory
-
_meta
ClassMetaData _meta
-
_projTypes
Class[] _projTypes
-
_subs
boolean _subs
-
-
Class org.apache.openjpa.kernel.FetchConfigurationImpl extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_availableDepth
int _availableDepth
-
_availableRecursion
int _availableRecursion
-
_directRelationOwner
String _directRelationOwner
-
_fromField
String _fromField
-
_fromType
Class<?> _fromType
-
_load
boolean _load
-
_parent
FetchConfigurationImpl _parent
-
_state
FetchConfigurationImpl.ConfigurationState _state
-
-
Class org.apache.openjpa.kernel.FetchConfigurationImpl.ConfigurationState extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
cacheNonDefaultFetchPlanQueries
boolean cacheNonDefaultFetchPlanQueries
-
cacheRetrieveMode
DataCacheRetrieveMode cacheRetrieveMode
-
cacheStoreMode
DataCacheStoreMode cacheStoreMode
-
extendedPathLookup
boolean extendedPathLookup
-
fetchBatchSize
int fetchBatchSize
-
fetchGroupContainsAll
boolean fetchGroupContainsAll
-
fetchGroupContainsDefault
boolean fetchGroupContainsDefault
-
fetchGroupIsPUDefault
boolean fetchGroupIsPUDefault
-
fetchGroups
Set<String> fetchGroups
-
fields
Set<String> fields
-
flushQuery
int flushQuery
-
hints
Map<String,Object> hints
-
lockScope
int lockScope
-
lockTimeout
int lockTimeout
-
maxFetchDepth
int maxFetchDepth
-
queryCache
boolean queryCache
-
queryTimeout
int queryTimeout
-
readLockLevel
int readLockLevel
-
rootClasses
Set<Class<?>> rootClasses
-
rootInstances
Set<Object> rootInstances
-
writeLockLevel
int writeLockLevel
-
-
Class org.apache.openjpa.kernel.FinalizingBrokerImpl extends BrokerImpl implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.kernel.MethodStoreQuery extends AbstractStoreQuery implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_params
OrderedMap<Object,Class<?>> _params
-
-
Class org.apache.openjpa.kernel.OpenJPASavepoint extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_broker
Broker _broker
-
_copy
boolean _copy
-
_name
String _name
-
_saved
Map<StateManagerImpl,org.apache.openjpa.kernel.SavepointFieldManager> _saved
-
-
Class org.apache.openjpa.kernel.PCDataImpl extends AbstractPCData implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.kernel.PCState extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialization Methods
-
readResolve
protected Object readResolve() throws ObjectStreamException
- Throws:
ObjectStreamException
-
-
Class org.apache.openjpa.kernel.PNonTransDeletedState extends PCState implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.kernel.QueryImpl extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_aggListeners
Map<String,AggregateListener> _aggListeners
-
_class
Class<?> _class
-
_fc
FetchConfiguration _fc
-
_filtListeners
Map<String,FilterListener> _filtListeners
-
_ignoreChanges
boolean _ignoreChanges
-
_language
String _language
-
_lock
ReentrantLock _lock
-
_params
String _params
-
_printParameters
boolean _printParameters
-
_query
String _query
-
_readOnly
boolean _readOnly
-
_resultClass
Class<?> _resultClass
-
_resultMappingName
String _resultMappingName
-
_resultMappingScope
Class<?> _resultMappingScope
-
_storeQuery
StoreQuery _storeQuery
-
_subclasses
boolean _subclasses
-
_unique
Boolean _unique
-
-
Class org.apache.openjpa.kernel.QueryImpl.Compilation extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
datastore
StoreQuery.Executor datastore
-
memory
StoreQuery.Executor memory
-
storeData
Object storeData
-
-
Class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialization Methods
-
writeReplace
public Object writeReplace()
-
-
Serialized Fields
-
_res
ResultList _res
-
-
Class org.apache.openjpa.kernel.QueryStatistics.Default extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.kernel.QueryStatistics.None extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.kernel.ResultShape extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
alias
String alias
-
children
List<ResultShape<?>> children
-
cls
Class<T> cls
-
isNesting
boolean isNesting
-
isPrimitive
boolean isPrimitive
-
parents
Set<ResultShape<?>> parents
-
strategy
FillStrategy<T> strategy
-
-
Class org.apache.openjpa.kernel.SaveFieldManager extends org.apache.openjpa.kernel.ClearFieldManager implements Serializable
- serialVersionUID:
- 1L
-
Serialization Methods
-
readObject
private void readObject(ObjectInputStream ois) throws IOException, ClassNotFoundException
- Throws:
IOException
ClassNotFoundException
-
writeObject
private void writeObject(ObjectOutputStream oos) throws IOException
- Throws:
IOException
-
-
Serialized Fields
-
_copyField
int[] _copyField
-
_field
Object _field
-
_saved
BitSet _saved
-
_sm
StateManagerImpl _sm
-
_unloaded
BitSet _unloaded
-
-
Class org.apache.openjpa.kernel.StateManagerImpl extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialization Methods
-
readObject
private void readObject(ObjectInputStream in) throws IOException, ClassNotFoundException
- Throws:
IOException
ClassNotFoundException
-
writeObject
private void writeObject(ObjectOutputStream oos) throws IOException
- Throws:
IOException
-
-
Serialized Fields
-
_datePrecision
int _datePrecision
-
_delayed
BitSet _delayed
-
_dirty
BitSet _dirty
-
_fieldImpl
Object[] _fieldImpl
-
_flags
int _flags
-
_flush
BitSet _flush
-
_fm
FieldManager _fm
-
_id
Object _id
-
_impl
Object _impl
-
_loaded
BitSet _loaded
-
_loadVersion
Object _loadVersion
-
_lock
Object _lock
-
_mappedByIdFields
List<FieldMetaData> _mappedByIdFields
-
_oid
Object _oid
-
_owner
StateManagerImpl _owner
-
_ownerId
Object _ownerId
-
_ownerIndex
int _ownerIndex
-
_readLockLevel
int _readLockLevel
-
_saved
SaveFieldManager _saved
-
_single
org.apache.openjpa.kernel.SingleFieldManager _single
-
_state
PCState _state
-
_version
Object _version
-
_writeLockLevel
int _writeLockLevel
-
postLoadCallback
boolean postLoadCallback
set to
false
to prevent the postLoad method from sending lifecycle callback events.Callbacks are enabled by default>
-
-
-
Package org.apache.openjpa.kernel.exps
-
Class org.apache.openjpa.kernel.exps.CandidatePath extends Val implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_actions
LinkedList _actions
-
_correlationVar
String _correlationVar
-
-
Class org.apache.openjpa.kernel.exps.Coalesce extends Val implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_val
Val[] _val
-
-
Class org.apache.openjpa.kernel.exps.Context extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
aliasCount
int aliasCount
-
cloneFrom
Context cloneFrom
-
from
Expression from
-
meta
ClassMetaData meta
-
parent
Context parent
-
parsed
JPQLExpressionBuilder.ParsedJPQL parsed
-
schemaAlias
String schemaAlias
-
schemas
Map<String,ClassMetaData> schemas
-
select
Object select
-
subquery
Subquery subquery
-
subsels
List<Context> subsels
-
variables
Map<String,Value> variables
-
-
Class org.apache.openjpa.kernel.exps.Exp extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.kernel.exps.NullIf extends Val implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.kernel.exps.QueryExpressions extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_aggregate
Boolean _aggregate
-
_contexts
Stack<Context> _contexts
-
accessPath
ClassMetaData[] accessPath
-
alias
String alias
-
ascending
boolean[] ascending
-
distinct
int distinct
-
fetchInnerPaths
String[] fetchInnerPaths
-
fetchPaths
String[] fetchPaths
-
filter
Expression filter
-
grouping
Value[] grouping
-
groupingClauses
String[] groupingClauses
-
hasInExpression
boolean hasInExpression
-
having
Expression having
-
operation
int operation
-
ordering
Value[] ordering
-
orderingAliases
String[] orderingAliases
-
orderingClauses
String[] orderingClauses
-
parameterTypes
OrderedMap<Object,Class<?>> parameterTypes
-
projectionAliases
String[] projectionAliases
-
projectionClauses
String[] projectionClauses
-
projections
Value[] projections
-
range
Value[] range
-
resultClass
Class<?> resultClass
-
shape
ResultShape<?> shape
-
state
Object state
-
updates
Map<Path,Value> updates
Map ofFieldMetaData
,Value
for update statements.
-
-
Class org.apache.openjpa.kernel.exps.SimpleCase extends Val implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.kernel.exps.StringContains extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.kernel.exps.Val extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_alias
String _alias
-
_meta
ClassMetaData _meta
-
-
Class org.apache.openjpa.kernel.exps.WhenCondition extends Exp implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.kernel.exps.WhenScalar extends Exp implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.kernel.exps.WildcardMatch extends Object implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.openjpa.kernel.jpql
-
Class org.apache.openjpa.kernel.jpql.JPQLExpressionBuilder.JPQLNode extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
children
JPQLExpressionBuilder.JPQLNode[] children
-
id
int id
-
inEnumPath
boolean inEnumPath
-
not
boolean not
-
parent
JPQLExpressionBuilder.JPQLNode parent
-
parser
JPQL parser
-
text
String text
-
-
Class org.apache.openjpa.kernel.jpql.JPQLExpressionBuilder.ParsedJPQL extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.kernel.jpql.JPQLParser extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.kernel.jpql.ParseException extends UserException implements Serializable
-
Class org.apache.openjpa.kernel.jpql.SimpleNode extends JPQLExpressionBuilder.JPQLNode implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.kernel.jpql.Token extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
beginColumn
int beginColumn
The column number of the first character of this Token. -
beginLine
int beginLine
The line number of the first character of this Token. -
endColumn
int endColumn
The column number of the last character of this Token. -
endLine
int endLine
The line number of the last character of this Token. -
image
String image
The string image of the token. -
kind
int kind
An integer that describes the kind of this token. This numbering system is determined by JavaCCParser, and a table of these numbers is stored in the file ...Constants.java. -
next
Token next
A reference to the next regular (non-special) token from the input stream. If this is the last token from the input stream, or if the token manager has not read tokens beyond this one, this field is set to null. This is true only if this token is also a regular token. Otherwise, see below for a description of the contents of this field. -
specialToken
Token specialToken
This field is used to access special tokens that occur prior to this token, but after the immediately preceding regular (non-special) token. If there are no such special tokens, this field is set to null. When there are more than one such special token, this field refers to the last of these special tokens, which in turn refers to the next previous special token through its specialToken field, and so on until the first special token (whose specialToken field is null). The next fields of special tokens refer to other special tokens that immediately follow it (without an intervening regular token). If there is no such token, this field is null.
-
-
Class org.apache.openjpa.kernel.jpql.TokenMgrError extends Error implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
errorCode
int errorCode
Indicates the reason why the exception is thrown. It will have one of the above 4 values.
-
-
-
Package org.apache.openjpa.meta
-
Class org.apache.openjpa.meta.ClassMetaData extends Extensions implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_abstract
boolean _abstract
-
_accessType
int _accessType
-
_alias
String _alias
-
_allDFGFields
FieldMetaData[] _allDFGFields
-
_allFields
FieldMetaData[] _allFields
-
_allListingFields
FieldMetaData[] _allListingFields
-
_allLrsFields
FieldMetaData[] _allLrsFields
-
_allPKFields
FieldMetaData[] _allPKFields
-
_allProxyFields
FieldMetaData[] _allProxyFields
-
_cacheEnabled
Boolean _cacheEnabled
-
_cacheName
String _cacheName
-
_cacheTimeout
int _cacheTimeout
-
_colNum
int _colNum
-
_comments
String[] _comments
-
_customFGs
FetchGroup[] _customFGs
-
_dataCacheEnabled
boolean _dataCacheEnabled
-
_definedFields
FieldMetaData[] _definedFields
-
_defSupFields
boolean _defSupFields
-
_detachable
Boolean _detachable
-
_detachState
String _detachState
-
_embeddable
boolean _embeddable
-
_embedded
Boolean _embedded
-
_extent
Boolean _extent
-
_fgMap
Map<String,FetchGroup> _fgMap
-
_fgs
FetchGroup[] _fgs
-
_fieldDataTable
int[] _fieldDataTable
-
_fieldMap
Map<String,FieldMetaData> _fieldMap
-
_fields
FieldMetaData[] _fields
-
_hasAbstractPKField
Boolean _hasAbstractPKField
-
_hashCode
int _hashCode
-
_hasPKFieldsFromAbstractClass
Boolean _hasPKFieldsFromAbstractClass
-
_idClass
Class<?> _idClass
-
_identity
Integer _identity
-
_idStrategy
int _idStrategy
-
_ifaceMap
Map<Class<?>,Map<String,String>> _ifaceMap
-
_impl
Class<?> _impl
-
_intercepting
boolean _intercepting
-
_interface
Boolean _interface
-
_interfaces
List<Class<?>> _interfaces
-
_lifeMeta
LifecycleMetaData _lifeMeta
-
_lineNum
int _lineNum
-
_listIndex
int _listIndex
-
_listingFields
FieldMetaData[] _listingFields
-
_mappedByIdFields
List<FieldMetaData> _mappedByIdFields
-
_mappedByIdFieldsSet
boolean _mappedByIdFieldsSet
-
_mapSubMetas
ClassMetaData[] _mapSubMetas
-
_objectId
Class<?> _objectId
-
_objectIdShared
Boolean _objectIdShared
-
_openjpaId
Boolean _openjpaId
-
_owner
ValueMetaData _owner
-
_pkAndNonPersistentManagedFmdIndexes
int[] _pkAndNonPersistentManagedFmdIndexes
-
_repos
MetaDataRepository _repos
-
_resMode
int _resMode
-
_seqMeta
SequenceMetaData _seqMeta
-
_seqName
String _seqName
-
_srcFile
File _srcFile
-
_srcMode
int _srcMode
-
_srcName
String _srcName
-
_srcType
int _srcType
-
_staticFields
Collection<String> _staticFields
-
_subMetas
ClassMetaData[] _subMetas
-
_subs
Class<?>[] _subs
-
_super
Class<?> _super
-
_superMeta
ClassMetaData _superMeta
-
_supFieldMap
Map<String,FieldMetaData> _supFieldMap
-
_type
Class<?> _type
-
_typeString
String _typeString
-
_unmgdFields
FieldMetaData[] _unmgdFields
-
_useIdClassFromParent
Boolean _useIdClassFromParent
-
_useSchemaElement
boolean _useSchemaElement
-
_versionIdx
int _versionIdx
-
inverseManagedFields
Boolean inverseManagedFields
-
-
Class org.apache.openjpa.meta.Extensions extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.meta.FetchGroup extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_containedBy
Set<String> _containedBy
-
_depths
Map<FieldMetaData,Number> _depths
-
_includes
List<String> _includes
-
_meta
ClassMetaData _meta
-
_name
String _name
-
_postLoad
Boolean _postLoad
-
_readOnly
boolean _readOnly
-
-
Class org.apache.openjpa.meta.FieldMetaData extends Extensions implements Serializable
- serialVersionUID:
- -566180883009883198L
-
Serialized Fields
-
_access
int _access
-
_associationType
int _associationType
-
_backingMember
FieldMetaData.MemberProvider _backingMember
-
_comments
String[] _comments
-
_converter
Class _converter
-
_dec
Class<?> _dec
-
_decIndex
int _decIndex
-
_decMeta
ClassMetaData _decMeta
-
_delayCapable
Boolean _delayCapable
-
_dfg
int _dfg
-
_elem
ValueMetaData _elem
-
_embedFullName
String _embedFullName
-
_enumField
Boolean _enumField
-
_explicit
boolean _explicit
-
_extName
String _extName
-
_extString
String _extString
-
_extValues
Map _extValues
-
_factName
String _factName
-
_fgs
String[] _fgs
-
_fgSet
Set<String> _fgSet
-
_fieldValues
Map _fieldValues
-
_fullName
String _fullName
-
_generated
boolean _generated
-
_implData
Boolean _implData
-
_index
int _index
-
_initializer
Object _initializer
-
_intermediate
boolean _intermediate
-
_inverse
String _inverse
-
_inverses
FieldMetaData[] _inverses
-
_isElementCollection
boolean _isElementCollection
-
_key
ValueMetaData _key
-
_lfg
String _lfg
-
_listIndex
int _listIndex
-
_lobField
Boolean _lobField
-
_lrs
Boolean _lrs
-
_manage
int _manage
-
_mappedBy
String _mappedBy
-
_mappedByIdValue
String _mappedByIdValue
-
_mappedByMeta
FieldMetaData _mappedByMeta
-
_name
String _name
-
_nullValue
int _nullValue
-
_orderDec
String _orderDec
-
_orders
Order[] _orders
-
_owner
ClassMetaData _owner
-
_persistentCollection
boolean _persistentCollection
-
_pkIndex
int _pkIndex
-
_primKey
boolean _primKey
-
_proxyClass
Class<?> _proxyClass
-
_relationType
Class<?> _relationType
-
_resMode
int _resMode
-
_seqMeta
SequenceMetaData _seqMeta
-
_seqName
String _seqName
-
_serializableField
Boolean _serializableField
-
_stream
Boolean _stream
-
_transient
boolean _transient
-
_upStrategy
int _upStrategy
-
_usedInOrderBy
boolean _usedInOrderBy
-
_useSchemaElement
boolean _useSchemaElement
-
_val
ValueMetaData _val
-
_valStrategy
int _valStrategy
-
_version
Boolean _version
-
-
Class org.apache.openjpa.meta.FieldMetaData.MemberProvider extends Object implements Serializable
-
Serialization Methods
-
readExternal
public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException
- Throws:
IOException
ClassNotFoundException
-
writeExternal
public void writeExternal(ObjectOutput out) throws IOException
- Throws:
IOException
-
-
-
Class org.apache.openjpa.meta.InheritanceComparator extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_base
Class _base
-
-
Class org.apache.openjpa.meta.LifecycleMetaData extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_activated
boolean _activated
-
_all
LifecycleCallbacks[][] _all
-
_declared
LifecycleCallbacks[][] _declared
-
_high
int[] _high
-
_ignoreSups
int _ignoreSups
-
_ignoreSystem
boolean _ignoreSystem
-
_meta
ClassMetaData _meta
-
_resolved
boolean _resolved
-
_super
LifecycleCallbacks[][] _super
-
_superHigh
int[] _superHigh
-
-
Class org.apache.openjpa.meta.MetaDataInheritanceComparator extends InheritanceComparator implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.meta.MetaDataRepository extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_aliases
Map<String,List<Class<?>>> _aliases
-
_errs
List<RuntimeException> _errs
-
_filterRegisteredClasses
boolean _filterRegisteredClasses
-
_ifaces
Map<Class<?>,Class<?>> _ifaces
-
_impls
Map<Class<?>,Collection<Class<?>>> _impls
-
_listeners
LifecycleEventManager.ListenerList _listeners
-
_locking
boolean _locking
-
_logEnhancementLevel
boolean _logEnhancementLevel
-
_mapping
List<ClassMetaData> _mapping
-
_metamodel
Map<Class<?>,Class<?>> _metamodel
-
_metas
Map<Class<?>,ClassMetaData> _metas
-
_metaStringMap
Map<String,ClassMetaData> _metaStringMap
-
_nonMapped
Map<Class<?>,NonPersistentMetaData> _nonMapped
-
_oids
Map<Class<?>,Class<?>> _oids
-
_pawares
Map<Class<?>,NonPersistentMetaData> _pawares
-
_preload
boolean _preload
-
_preloadComplete
boolean _preloadComplete
-
_queries
Map<String,QueryMetaData> _queries
-
_registered
Collection<Class<?>> _registered
-
_resMode
int _resMode
-
_resolving
List<ClassMetaData> _resolving
-
_seqs
Map<String,SequenceMetaData> _seqs
-
_sourceMode
int _sourceMode
-
_subs
Map<Class<?>,Collection<Class<?>>> _subs
-
_sysSeq
SequenceMetaData _sysSeq
-
_systemListenersActivated
boolean _systemListenersActivated
-
_typesWithoutEnhancement
Collection<Class<?>> _typesWithoutEnhancement
-
_validate
int _validate
-
_xmlmetas
Map<Class<?>,XMLMetaData> _xmlmetas
-
EMPTY_FIELDS
FieldMetaData[] EMPTY_FIELDS
-
EMPTY_METAS
ClassMetaData[] EMPTY_METAS
-
EMPTY_ORDERS
Order[] EMPTY_ORDERS
-
EMPTY_XMLMETAS
XMLMetaData[] EMPTY_XMLMETAS
-
-
Class org.apache.openjpa.meta.MultiQueryMetaData extends QueryMetaData implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_isTemporary
boolean _isTemporary
-
_params
List<MultiQueryMetaData.Parameter> _params
-
_parts
List<QueryMetaData> _parts
-
_procedureName
String _procedureName
-
-
Class org.apache.openjpa.meta.NonPersistentMetaData extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_class
Class _class
-
_colNum
int _colNum
-
_comments
String[] _comments
-
_lineNum
int _lineNum
-
_listIndex
int _listIndex
-
_repos
MetaDataRepository _repos
-
_srcFile
File _srcFile
-
_srcType
int _srcType
-
_type
int _type
-
-
Class org.apache.openjpa.meta.QueryMetaData extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_candidate
Class _candidate
-
_class
Class _class
-
_colNum
int _colNum
-
_comments
String[] _comments
-
_convertPositionalParametersToNamed
boolean _convertPositionalParametersToNamed
-
_file
File _file
-
_hintKeys
List _hintKeys
-
_hintVals
List _hintVals
-
_language
String _language
-
_lineNum
int _lineNum
-
_mode
int _mode
-
_name
String _name
-
_paramTypes
OrderedMap<Object,Class<?>> _paramTypes
-
_query
String _query
-
_readOnly
Boolean _readOnly
-
_res
Class _res
-
_resultSetMappingName
String _resultSetMappingName
-
_scope
Object _scope
-
_srcName
String _srcName
-
_srcType
int _srcType
-
-
Class org.apache.openjpa.meta.SequenceMetaData extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_allocate
int _allocate
-
_catalog
String _catalog
-
_colNum
int _colNum
-
_comments
String[] _comments
-
_factory
SequenceMetaData.SequenceFactory _factory
-
_increment
int _increment
-
_initial
int _initial
-
_lineNum
int _lineNum
-
_name
String _name
-
_plugin
String _plugin
-
_repos
MetaDataRepository _repos
-
_schema
String _schema
-
_scope
Object _scope
-
_sequence
String _sequence
-
_source
File _source
-
_srcType
int _srcType
-
_type
int _type
-
-
Class org.apache.openjpa.meta.ValueMetaDataImpl extends Object implements Serializable
- serialVersionUID:
- 6766697443293395831L
-
Serialized Fields
-
_attach
int _attach
-
_checkPUDefaultCascadePersist
boolean _checkPUDefaultCascadePersist
-
_code
int _code
-
_decCode
int _decCode
-
_decType
Class _decType
-
_decTypeMeta
ClassMetaData _decTypeMeta
-
_delete
int _delete
-
_detach
int _detach
-
_embedded
Boolean _embedded
-
_embeddedMeta
ClassMetaData _embeddedMeta
-
_mappedBy
String _mappedBy
-
_mappedByMeta
FieldMetaData _mappedByMeta
-
_owner
FieldMetaData _owner
-
_persist
int _persist
-
_refresh
int _refresh
-
_resMode
int _resMode
-
_serialized
boolean _serialized
-
_type
Class _type
-
_typeMeta
ClassMetaData _typeMeta
-
_typeOverride
Class _typeOverride
-
-
Class org.apache.openjpa.meta.XMLClassMetaData extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.meta.XMLFieldMetaData extends Object implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.openjpa.util
-
Class org.apache.openjpa.util.BigDecimalId extends OpenJPAId implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
key
BigDecimal key
-
-
Class org.apache.openjpa.util.BigIntegerId extends OpenJPAId implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
key
BigInteger key
-
-
Class org.apache.openjpa.util.BooleanId extends OpenJPAId implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
key
boolean key
-
-
Class org.apache.openjpa.util.ByteId extends OpenJPAId implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
key
byte key
-
-
Class org.apache.openjpa.util.CallbackException extends UserException implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.util.CharId extends OpenJPAId implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
key
char key
-
-
Class org.apache.openjpa.util.DateId extends OpenJPAId implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
key
Date key
-
-
Class org.apache.openjpa.util.DoubleId extends OpenJPAId implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
key
double key
-
-
Class org.apache.openjpa.util.FloatId extends OpenJPAId implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
key
float key
-
-
Class org.apache.openjpa.util.GeneralException extends OpenJPAException implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.util.Id extends OpenJPAId implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_id
long _id
-
-
Class org.apache.openjpa.util.InternalException extends OpenJPAException implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.util.IntId extends OpenJPAId implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
key
int key
-
-
Class org.apache.openjpa.util.InvalidStateException extends UserException implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.util.LockException extends StoreException implements Serializable
- serialVersionUID:
- 1L
-
Serialization Methods
-
readObject
private void readObject(ObjectInputStream in) throws IOException, ClassNotFoundException
- Throws:
IOException
ClassNotFoundException
-
writeObject
private void writeObject(ObjectOutputStream out) throws IOException
- Throws:
IOException
-
-
Serialized Fields
-
lockLevel
int lockLevel
-
timeout
int timeout
-
-
Class org.apache.openjpa.util.LongId extends OpenJPAId implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
key
long key
-
-
Class org.apache.openjpa.util.MetaDataException extends UserException implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.util.NonUniqueResultException extends InvalidStateException implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.util.NoResultException extends InvalidStateException implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.util.NoTransactionException extends InvalidStateException implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.util.ObjectExistsException extends StoreException implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.util.ObjectId extends OpenJPAId implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_key
Object _key
-
-
Class org.apache.openjpa.util.ObjectNotFoundException extends StoreException implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.util.OpenJPAException extends RuntimeException implements Serializable
- serialVersionUID:
- 1L
-
Serialization Methods
-
readObject
private void readObject(ObjectInputStream in) throws IOException, ClassNotFoundException
- Throws:
IOException
ClassNotFoundException
-
writeObject
private void writeObject(ObjectOutputStream out) throws IOException
- Throws:
IOException
-
-
Class org.apache.openjpa.util.OpenJPAId extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_typeHash
int _typeHash
-
subs
boolean subs
-
type
Class type
-
-
Class org.apache.openjpa.util.OptimisticException extends StoreException implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.util.QueryException extends StoreException implements Serializable
- serialVersionUID:
- 1L
-
Serialization Methods
-
readObject
private void readObject(ObjectInputStream in) throws IOException, ClassNotFoundException
- Throws:
IOException
ClassNotFoundException
-
writeObject
private void writeObject(ObjectOutputStream out) throws IOException
- Throws:
IOException
-
-
Serialized Fields
-
timeout
int timeout
-
-
Class org.apache.openjpa.util.ReferentialIntegrityException extends StoreException implements Serializable
- serialVersionUID:
- 1L
-
Serialization Methods
-
readObject
private void readObject(ObjectInputStream in) throws IOException, ClassNotFoundException
- Throws:
IOException
ClassNotFoundException
-
writeObject
private void writeObject(ObjectOutputStream out) throws IOException
- Throws:
IOException
-
-
Serialized Fields
-
_iv
int _iv
-
-
Class org.apache.openjpa.util.ShortId extends OpenJPAId implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
key
short key
-
-
Class org.apache.openjpa.util.StoreException extends OpenJPAException implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.util.StringId extends OpenJPAId implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
key
String key
-
-
Class org.apache.openjpa.util.UnsupportedException extends OpenJPAException implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.util.UserException extends OpenJPAException implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.util.WrappedException extends OpenJPAException implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.openjpa.util.proxy
-
Class org.apache.openjpa.util.proxy.DelayedArrayListProxy extends ArrayList implements Serializable
-
Serialization Methods
-
writeReplace
protected Object writeReplace() throws ObjectStreamException
- Throws:
ObjectStreamException
-
-
-
Class org.apache.openjpa.util.proxy.DelayedHashSetProxy extends HashSet implements Serializable
-
Serialization Methods
-
writeReplace
protected Object writeReplace() throws ObjectStreamException
- Throws:
ObjectStreamException
-
-
-
Class org.apache.openjpa.util.proxy.DelayedLinkedHashSetProxy extends LinkedHashSet implements Serializable
-
Serialization Methods
-
writeReplace
protected Object writeReplace() throws ObjectStreamException
- Throws:
ObjectStreamException
-
-
-
Class org.apache.openjpa.util.proxy.DelayedLinkedListProxy extends LinkedList implements Serializable
-
Serialization Methods
-
writeReplace
protected Object writeReplace() throws ObjectStreamException
- Throws:
ObjectStreamException
-
-
-
Class org.apache.openjpa.util.proxy.DelayedPriorityQueueProxy extends PriorityQueue implements Serializable
-
Serialization Methods
-
writeReplace
protected Object writeReplace() throws ObjectStreamException
- Throws:
ObjectStreamException
-
-
-
Class org.apache.openjpa.util.proxy.DelayedTreeSetProxy extends TreeSet implements Serializable
-
Serialization Methods
-
writeReplace
protected Object writeReplace() throws ObjectStreamException
- Throws:
ObjectStreamException
-
-
-
Class org.apache.openjpa.util.proxy.DelayedVectorProxy extends Vector implements Serializable
-
Serialization Methods
-
writeReplace
protected Object writeReplace() throws ObjectStreamException
- Throws:
ObjectStreamException
-
-
-
-
Package org.apache.openjpa.validation
-
Class org.apache.openjpa.validation.ValidatingLifecycleEventManager extends LifecycleEventManager implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
_conf
OpenJPAConfiguration _conf
-
_validationEnabled
boolean _validationEnabled
-
_validator
Validator _validator
-
-
Class org.apache.openjpa.validation.ValidationException extends WrappedException implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.openjpa.validation.ValidationUnavailableException extends OpenJPAException implements Serializable
- serialVersionUID:
- 1L
-