A B C D E F G H I J K L M N O P Q R S T U V W X Z _

A

abortUnion() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
abortUnion() - Method in interface org.apache.openjpa.jdbc.sql.Union
Force the use of a series of standard selects rather than a true UNION.
abs(Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
abs(Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return a value representing the absolute value of the given one.
abs(Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
absolute(int) - Method in class org.apache.openjpa.jdbc.kernel.GenericResultObjectProvider
 
absolute(int) - Method in class org.apache.openjpa.jdbc.kernel.PagingResultObjectProvider
 
absolute(int) - Method in class org.apache.openjpa.jdbc.kernel.SelectResultObjectProvider
 
absolute(int) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
absolute(int) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
absolute(int) - Method in interface org.apache.openjpa.jdbc.sql.Result
Move to the given 0-based row in the result, or return false if the row does not exist.
absolute(int) - Method in class org.apache.openjpa.kernel.AbstractPCResultObjectProvider
Override if desired.
absolute(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
absolute(int) - Method in class org.apache.openjpa.lib.rop.ListResultObjectProvider
 
absolute(int) - Method in class org.apache.openjpa.lib.rop.MergedResultObjectProvider
 
absolute(int) - Method in class org.apache.openjpa.lib.rop.RangeResultObjectProvider
 
absolute(int) - Method in interface org.apache.openjpa.lib.rop.ResultObjectProvider
Move to the given 0-based position.
absoluteInternal(int) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
Throws an exception by default.
absoluteInternal(int) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
absoluteInternal(int) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
AbstractBrokerFactory - Class in org.apache.openjpa.kernel
Abstract implementation of the BrokerFactory that must be subclassed for a specific runtime.
AbstractBrokerFactory(OpenJPAConfiguration) - Constructor for class org.apache.openjpa.kernel.AbstractBrokerFactory
Constructor.
AbstractCFMetaDataFactory - Class in org.apache.openjpa.meta
Base class for factory implementations built around XML metadata files in the common fomat.
AbstractCFMetaDataFactory() - Constructor for class org.apache.openjpa.meta.AbstractCFMetaDataFactory
 
AbstractCFMetaDataFactory.Parser - Interface in org.apache.openjpa.meta
Internal parser interface.
AbstractCFMetaDataFactory.Serializer - Interface in org.apache.openjpa.meta
Internal serializer interface.
AbstractChangeTracker - Class in org.apache.openjpa.util
Base class that provides utilities to change trackers.
AbstractChangeTracker() - Constructor for class org.apache.openjpa.util.AbstractChangeTracker
Constructor; supply configuration.
AbstractClassStrategy - Class in org.apache.openjpa.jdbc.meta.strats
No-op strategy for easy extension.
AbstractClassStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.AbstractClassStrategy
 
AbstractConcurrentEventManager - Class in org.apache.openjpa.lib.util.concurrent
Base event manager that handles adding/removing listeners and firing events.
AbstractConcurrentEventManager() - Constructor for class org.apache.openjpa.lib.util.concurrent.AbstractConcurrentEventManager
Default constructor.
AbstractDataCache - Class in org.apache.openjpa.datacache
Abstract DataCache implementation that provides various statistics, logging, and timeout functionality common across cache implementations.
AbstractDataCache() - Constructor for class org.apache.openjpa.datacache.AbstractDataCache
 
AbstractDB2Dictionary - Class in org.apache.openjpa.jdbc.sql
Base dictionary for the IBM DB2 family of databases.
AbstractDB2Dictionary() - Constructor for class org.apache.openjpa.jdbc.sql.AbstractDB2Dictionary
 
AbstractDiscriminatorStrategy - Class in org.apache.openjpa.jdbc.meta.strats
No-op strategy for easy extension.
AbstractDiscriminatorStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.AbstractDiscriminatorStrategy
 
AbstractEventManager - Class in org.apache.openjpa.lib.util
Base event manager that handles adding/removing listeners and firing events.
AbstractEventManager() - Constructor for class org.apache.openjpa.lib.util.AbstractEventManager
 
AbstractExpressionBuilder - Class in org.apache.openjpa.kernel.exps
Abstract base class to help build expressions.
AbstractExpressionBuilder(ExpressionFactory, Resolver) - Constructor for class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
Constructor.
AbstractExpressionVisitor - Class in org.apache.openjpa.kernel.exps
No-op abstract visitor meant for easy extension.
AbstractExpressionVisitor() - Constructor for class org.apache.openjpa.kernel.exps.AbstractExpressionVisitor
 
AbstractFieldStrategy - Class in org.apache.openjpa.jdbc.meta.strats
No-op strategy for easy extension.
AbstractFieldStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
AbstractJDBCListener - Class in org.apache.openjpa.lib.jdbc
An abstract implementation of the JDBCListener listener.
AbstractJDBCListener() - Constructor for class org.apache.openjpa.lib.jdbc.AbstractJDBCListener
 
AbstractJDBCSavepointManager - Class in org.apache.openjpa.jdbc.kernel
Abstract SavepointManager implementation that delegates to the subclass for savepoint operations on the active Connection.
AbstractJDBCSavepointManager() - Constructor for class org.apache.openjpa.jdbc.kernel.AbstractJDBCSavepointManager
 
AbstractJDBCSavepointManager.ConnectionSavepoint - Class in org.apache.openjpa.jdbc.kernel
A savepoint which provides access to the current transactional connection.
AbstractJDBCSavepointManager.ConnectionSavepoint(Broker, String, boolean) - Constructor for class org.apache.openjpa.jdbc.kernel.AbstractJDBCSavepointManager.ConnectionSavepoint
 
AbstractJDBCSeq - Class in org.apache.openjpa.jdbc.kernel
Abstract sequence implementation.
AbstractJDBCSeq() - Constructor for class org.apache.openjpa.jdbc.kernel.AbstractJDBCSeq
 
AbstractLifecycleListener - Class in org.apache.openjpa.event
Abstract implementation of the LifecycleListener interface which delegates events to a single method.
AbstractLifecycleListener() - Constructor for class org.apache.openjpa.event.AbstractLifecycleListener
 
AbstractLockManager - Class in org.apache.openjpa.kernel
Abstract LockManager implementation.
AbstractLockManager() - Constructor for class org.apache.openjpa.kernel.AbstractLockManager
 
AbstractLog - Class in org.apache.openjpa.lib.log
A simple implementation of the Log interface.
AbstractLog() - Constructor for class org.apache.openjpa.lib.log.AbstractLog
 
AbstractLRSProxyCollection - Class in org.apache.openjpa.util
A collection proxy designed for collections backed by extremely large result sets in which each call to AbstractLRSProxyCollection.iterator() may perform a database query.
AbstractLRSProxyCollection(Class, boolean, OpenJPAConfiguration) - Constructor for class org.apache.openjpa.util.AbstractLRSProxyCollection
Constructor.
AbstractLRSProxyMap - Class in org.apache.openjpa.util
A map proxy designed for maps backed by extremely large result sets in which each call to AbstractLRSProxyMap.get(java.lang.Object) or AbstractLRSProxyMap.containsKey(java.lang.Object) may perform a database query.
AbstractLRSProxyMap(Class, Class, OpenJPAConfiguration) - Constructor for class org.apache.openjpa.util.AbstractLRSProxyMap
 
AbstractMetaDataDefaults - Class in org.apache.openjpa.meta
Abstract metadata defaults.
AbstractMetaDataDefaults() - Constructor for class org.apache.openjpa.meta.AbstractMetaDataDefaults
 
AbstractMetaDataFactory - Class in org.apache.openjpa.meta
Abstract MetaDataFactory that provides default implementations of many methods.
AbstractMetaDataFactory() - Constructor for class org.apache.openjpa.meta.AbstractMetaDataFactory
 
AbstractNonSequentialResultList - Class in org.apache.openjpa.lib.rop
Abstract base class for random-access result lists.
AbstractNonSequentialResultList() - Constructor for class org.apache.openjpa.lib.rop.AbstractNonSequentialResultList
 
AbstractPCData - Class in org.apache.openjpa.kernel
Abstract base class which implements core PCData behavior.
AbstractPCData() - Constructor for class org.apache.openjpa.kernel.AbstractPCData
 
AbstractPCResultObjectProvider - Class in org.apache.openjpa.kernel
Abstract implementation of PCResultObjectProvider that implements ResultObjectProvider.getResultObject() by assembling the necessary information about the object to be loaded.
AbstractPCResultObjectProvider(StoreContext) - Constructor for class org.apache.openjpa.kernel.AbstractPCResultObjectProvider
Create a new provider for loading PC objects from the input into ctx.
AbstractProductDerivation - Class in org.apache.openjpa.lib.conf
Abstract no-op product derivation for easy extension.
AbstractProductDerivation() - Constructor for class org.apache.openjpa.lib.conf.AbstractProductDerivation
 
AbstractQueryCache - Class in org.apache.openjpa.datacache
Abstract QueryCache implementation that provides various statistics, logging, and timeout functionality common across cache implementations.
AbstractQueryCache() - Constructor for class org.apache.openjpa.datacache.AbstractQueryCache
 
AbstractRemoteCommitProvider - Class in org.apache.openjpa.event
Abstract implementation of RemoteCommitProvider.
AbstractRemoteCommitProvider() - Constructor for class org.apache.openjpa.event.AbstractRemoteCommitProvider
 
AbstractResult - Class in org.apache.openjpa.jdbc.sql
A Result implementation designed to be subclassed easily by implementations.
AbstractResult() - Constructor for class org.apache.openjpa.jdbc.sql.AbstractResult
 
AbstractResultList - Class in org.apache.openjpa.lib.rop
Abstract base class for read-only result lists.
AbstractResultList() - Constructor for class org.apache.openjpa.lib.rop.AbstractResultList
 
AbstractSequentialResultList - Class in org.apache.openjpa.lib.rop
Abstract base class for sequential result lists.
AbstractSequentialResultList() - Constructor for class org.apache.openjpa.lib.rop.AbstractSequentialResultList
 
AbstractSQLServerDictionary - Class in org.apache.openjpa.jdbc.sql
Dictionary for the SQL Server databases (Sybase and MS SQL Server).
AbstractSQLServerDictionary() - Constructor for class org.apache.openjpa.jdbc.sql.AbstractSQLServerDictionary
 
AbstractStoreBrokerFactory - Class in org.apache.openjpa.abstractstore
BrokerFactory implementation for use with the AbstractStoreManager.
AbstractStoreBrokerFactory(OpenJPAConfiguration, String, String, String) - Constructor for class org.apache.openjpa.abstractstore.AbstractStoreBrokerFactory
Construct the factory with the given settings.
AbstractStoreManager - Class in org.apache.openjpa.abstractstore
Abstract store manager implementation to ease development of custom OpenJPA back-ends.
AbstractStoreManager() - Constructor for class org.apache.openjpa.abstractstore.AbstractStoreManager
 
AbstractStoreQuery - Class in org.apache.openjpa.kernel
Abstract StoreQuery that implements most methods as no-ops.
AbstractStoreQuery() - Constructor for class org.apache.openjpa.kernel.AbstractStoreQuery
 
AbstractStoreQuery.AbstractExecutor - Class in org.apache.openjpa.kernel
Abstract AbstractStoreQuery.AbstractExecutor that implements most methods as no-ops.
AbstractStoreQuery.AbstractExecutor() - Constructor for class org.apache.openjpa.kernel.AbstractStoreQuery.AbstractExecutor
 
AbstractStrategy - Class in org.apache.openjpa.jdbc.meta.strats
No-op strategy for easy extension.
AbstractStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.AbstractStrategy
 
AbstractTask - Class in org.apache.openjpa.lib.ant
Ant tasks all have a nested <config&rt; tag, which uses the configuration as a bean-like task.
AbstractTask() - Constructor for class org.apache.openjpa.lib.ant.AbstractTask
 
AbstractTransactionListener - Class in org.apache.openjpa.event
Abstract implementation of the TransactionListener interface that provides no-op implementations of all methods.
AbstractTransactionListener() - Constructor for class org.apache.openjpa.event.AbstractTransactionListener
 
AbstractUpdateManager - Class in org.apache.openjpa.jdbc.kernel
Base update manager with common functionality.
AbstractUpdateManager() - Constructor for class org.apache.openjpa.jdbc.kernel.AbstractUpdateManager
 
AbstractValueHandler - Class in org.apache.openjpa.jdbc.meta.strats
No-op implementations of ValueHandler interface methods.
AbstractValueHandler() - Constructor for class org.apache.openjpa.jdbc.meta.strats.AbstractValueHandler
 
AbstractVersionStrategy - Class in org.apache.openjpa.jdbc.meta.strats
No-op strategy for easy extension.
AbstractVersionStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.AbstractVersionStrategy
 
acceptVisit(ExpressionVisitor) - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
 
acceptVisit(ExpressionVisitor) - Method in interface org.apache.openjpa.kernel.exps.Expression
Accept a visit from a tree visitor.
acceptVisit(ExpressionVisitor) - Method in class org.apache.openjpa.kernel.exps.Val
 
acceptVisit(ExpressionVisitor) - Method in interface org.apache.openjpa.kernel.exps.Value
Accept a visit from a tree visitor.
ACCESS_FIELD - Static variable in class org.apache.openjpa.meta.ClassMetaData
Persistent attributes are accessed via direct field access.
ACCESS_PROPERTY - Static variable in class org.apache.openjpa.meta.ClassMetaData
Persistent attributes are accessed via setters and getters.
ACCESS_UNKNOWN - Static variable in class org.apache.openjpa.meta.ClassMetaData
Unknown access type.
AccessDictionary - Class in org.apache.openjpa.jdbc.sql
Dictionary for Access via DataDirect SequeLink and DataDirect ODBC FoxPro driver.
AccessDictionary() - Constructor for class org.apache.openjpa.jdbc.sql.AccessDictionary
 
accessingField(int) - Method in interface org.apache.openjpa.enhance.StateManager
Field access callback.
accessingField(int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
accessingField(int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
accessingField(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
accessingField(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
accessPath - Variable in class org.apache.openjpa.kernel.exps.QueryExpressions
 
ACT_CASCADE - Static variable in interface org.apache.openjpa.kernel.OpCallbacks
 
ACT_NONE - Static variable in interface org.apache.openjpa.kernel.OpCallbacks
 
ACT_RUN - Static variable in interface org.apache.openjpa.kernel.OpCallbacks
 
action - Variable in class org.apache.openjpa.jdbc.meta.MappingTool.Flags
 
action - Variable in class org.apache.openjpa.jdbc.schema.SchemaTool.Flags
 
action - Variable in class org.apache.openjpa.meta.MetaDataTool.Flags
 
ACTION_ADD - Static variable in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
 
ACTION_ADD - Static variable in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
 
ACTION_ADD - Static variable in class org.apache.openjpa.jdbc.meta.MappingTool
 
ACTION_ADD - Static variable in class org.apache.openjpa.jdbc.schema.SchemaTool
 
ACTION_ADD - Static variable in class org.apache.openjpa.jdbc.schema.TableSchemaFactory
 
ACTION_ADD - Static variable in class org.apache.openjpa.meta.MetaDataTool
 
ACTION_BUILD - Static variable in class org.apache.openjpa.jdbc.schema.SchemaTool
 
ACTION_BUILD_SCHEMA - Static variable in class org.apache.openjpa.jdbc.meta.MappingTool
 
ACTION_CASCADE - Static variable in class org.apache.openjpa.jdbc.schema.ForeignKey
Cascade any modification of the joined primary key columns to this table.
ACTION_CREATEDB - Static variable in class org.apache.openjpa.jdbc.schema.SchemaTool
 
ACTION_DEFAULT - Static variable in class org.apache.openjpa.jdbc.schema.ForeignKey
Set the local columns to their default values if the primary key columns are modified.
ACTION_DELETE - Static variable in interface org.apache.openjpa.jdbc.sql.Row
Mark the row for deletion.
ACTION_DROP - Static variable in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
 
ACTION_DROP - Static variable in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
 
ACTION_DROP - Static variable in class org.apache.openjpa.jdbc.meta.MappingTool
 
ACTION_DROP - Static variable in class org.apache.openjpa.jdbc.schema.SchemaTool
 
ACTION_DROP - Static variable in class org.apache.openjpa.jdbc.schema.TableSchemaFactory
 
ACTION_DROP - Static variable in class org.apache.openjpa.meta.MetaDataTool
 
ACTION_DROPDB - Static variable in class org.apache.openjpa.jdbc.schema.SchemaTool
 
ACTION_EXCEPTION - Static variable in class org.apache.openjpa.kernel.InverseManager
Constant representing the InverseManager.ACTION_EXCEPTION action
ACTION_EXPORT - Static variable in class org.apache.openjpa.jdbc.meta.MappingTool
 
ACTION_EXPORT - Static variable in class org.apache.openjpa.jdbc.schema.SchemaTool
 
ACTION_GET - Static variable in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
 
ACTION_GET - Static variable in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
 
ACTION_IMPORT - Static variable in class org.apache.openjpa.jdbc.meta.MappingTool
 
ACTION_IMPORT - Static variable in class org.apache.openjpa.jdbc.schema.SchemaTool
 
ACTION_INSERT - Static variable in interface org.apache.openjpa.jdbc.sql.Row
Mark the row for inserttion.
ACTION_MANAGE - Static variable in class org.apache.openjpa.kernel.InverseManager
Constant representing the InverseManager.ACTION_MANAGE action
ACTION_NONE - Static variable in class org.apache.openjpa.jdbc.schema.ForeignKey
Logical foreign key; links columns, but does not perform any action when the joined primary key columns are modified.
ACTION_NULL - Static variable in class org.apache.openjpa.jdbc.schema.ForeignKey
Null the local columns if the joined primary key columns are modified.
ACTION_REFLECT - Static variable in class org.apache.openjpa.jdbc.schema.SchemaTool
 
ACTION_REFRESH - Static variable in class org.apache.openjpa.jdbc.meta.MappingTool
 
ACTION_REFRESH - Static variable in class org.apache.openjpa.jdbc.schema.SchemaTool
 
ACTION_RESTRICT - Static variable in class org.apache.openjpa.jdbc.schema.ForeignKey
Throw an exception if joined primary key columns are modified.
ACTION_RETAIN - Static variable in class org.apache.openjpa.jdbc.schema.SchemaTool
 
ACTION_SET - Static variable in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
 
ACTION_UNKNOWN - Static variable in interface org.apache.openjpa.jdbc.sql.Row
Symbolic constant reserved for situations when a row operation is unknown.
ACTION_UPDATE - Static variable in interface org.apache.openjpa.jdbc.sql.Row
Mark the row for update.
ACTION_VALIDATE - Static variable in class org.apache.openjpa.jdbc.meta.MappingTool
 
ACTION_WARN - Static variable in class org.apache.openjpa.kernel.InverseManager
Constant representing the InverseManager.ACTION_WARN action
ACTIONS - Static variable in class org.apache.openjpa.jdbc.meta.MappingTool
 
ACTIONS - Static variable in class org.apache.openjpa.jdbc.schema.SchemaTool
 
ACTIONS - Static variable in class org.apache.openjpa.meta.MetaDataTool
 
add(Object) - Method in class org.apache.openjpa.event.LifecycleEventManager.ListenerList
 
add(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
add(JDBCStore, Object, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapInverseKeyFieldStrategy
 
add(JDBCStore, Object, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapTableFieldStrategy
 
add(JDBCStore, Object, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.StoreCollectionFieldStrategy
Add an item to the data structure representing a field value.
add(Object) - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
add(int, Object) - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
add(Object) - Method in class org.apache.openjpa.kernel.DelegatingResultList.DelegatingListIterator
 
add(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return a value representing the two values added together.
add(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
add(Object, Class, Object, Class) - Static method in class org.apache.openjpa.kernel.Filters
Add the given values.
add(Object) - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
add(int, Object) - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
add(int, Object) - Method in class org.apache.openjpa.lib.rop.AbstractResultList
 
add(Object) - Method in class org.apache.openjpa.lib.rop.AbstractResultList
 
add(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashSet
 
add(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentLinkedQueue
Inserts the specified element at the tail of this queue.
add(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashSet
 
add(Object) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
add(int, Object) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
add(Object) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArraySet
Adds the specified element to this set if it is not already present.
add(Object) - Method in interface org.apache.openjpa.lib.util.concurrent.Queue
Inserts the specified element into this queue if it is possible to do so immediately without violating capacity restrictions, returning true upon success and throwing an IllegalStateException if no space is currently available.
add(Object) - Method in class org.apache.openjpa.lib.util.ReferenceHashSet
 
add - Variable in class org.apache.openjpa.util.AbstractChangeTracker
Collection of added items.
add(Object) - Method in class org.apache.openjpa.util.AbstractChangeTracker
Mark the given value as added.
add(Object) - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
add(Object) - Method in class org.apache.openjpa.util.CollectionChangeTrackerImpl
 
add(Object) - Method in class org.apache.openjpa.util.MapChangeTrackerImpl
 
add(int, Object) - Method in class org.apache.openjpa.util.ProxyArrayList
 
add(Object) - Method in class org.apache.openjpa.util.ProxyArrayList
 
add(int, int) - Method in class org.apache.openjpa.util.ProxyGregorianCalendar
 
add(Object) - Method in class org.apache.openjpa.util.ProxyHashSet
 
add(int, Object) - Method in class org.apache.openjpa.util.ProxyLinkedList
 
add(Object) - Method in class org.apache.openjpa.util.ProxyLinkedList
 
add(Object) - Method in class org.apache.openjpa.util.ProxyTreeSet
 
add(int, Object) - Method in class org.apache.openjpa.util.ProxyVector
 
add(Object) - Method in class org.apache.openjpa.util.ProxyVector
 
addAccessPath(ClassMetaData) - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
Register the specified metadata as being in the query's access path.
addAccessPathMetaDatas(List, ClassMetaData[]) - Static method in class org.apache.openjpa.kernel.Filters
Add the given access path metadatas to the full path list, making sure to maintain only base metadatas in the list.
addAggregateListener(AggregateListener) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
addAggregateListener(AggregateListener) - Method in interface org.apache.openjpa.kernel.Query
Register an aggregate listener for the query.
addAggregateListener(AggregateListener) - Method in class org.apache.openjpa.kernel.QueryImpl
 
addAggregateListener(AggregateListener) - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Register an aggregate listener for the query.
addAggregateListener(AggregateListener) - Method in class org.apache.openjpa.persistence.QueryImpl
 
addAll(Schema) - Method in interface org.apache.openjpa.jdbc.schema.SchemaSerializer
Add the given schema's objects to the set of objects that will be serialized.
addAll(SchemaGroup) - Method in interface org.apache.openjpa.jdbc.schema.SchemaSerializer
Add all the objects in the given group to the set of objects that will be serialized.
addAll(Schema) - Method in class org.apache.openjpa.jdbc.schema.XMLSchemaSerializer
 
addAll(SchemaGroup) - Method in class org.apache.openjpa.jdbc.schema.XMLSchemaSerializer
 
addAll(Collection) - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
addAll(int, Collection) - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
addAll(Collection) - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
addAll(int, Collection) - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
addAll(Collection) - Method in class org.apache.openjpa.lib.rop.AbstractResultList
 
addAll(int, Collection) - Method in class org.apache.openjpa.lib.rop.AbstractResultList
 
addAll(Collection) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashSet
 
addAll(Collection) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashSet
 
addAll(Collection) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
addAll(int, Collection) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
addAll(Collection) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArraySet
Adds all of the elements in the specified collection to this set if they're not already present.
addAll(Collection) - Method in class org.apache.openjpa.lib.util.ReferenceHashSet
 
addAll(MetaDataRepository) - Method in interface org.apache.openjpa.meta.AbstractCFMetaDataFactory.Serializer
Add all components in the given repository to the set to be serialized.
addAll(MetaDataRepository) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer
 
addAll(MetaDataRepository) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Add all components in the given repository to the set to be serialized.
addAll(Collection) - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
addAll(int, Collection) - Method in class org.apache.openjpa.util.ProxyArrayList
 
addAll(Collection) - Method in class org.apache.openjpa.util.ProxyArrayList
 
addAll(Collection) - Method in class org.apache.openjpa.util.ProxyHashSet
 
addAll(int, Collection) - Method in class org.apache.openjpa.util.ProxyLinkedList
 
addAll(Collection) - Method in class org.apache.openjpa.util.ProxyLinkedList
 
addAll(Collection) - Method in class org.apache.openjpa.util.ProxyTreeSet
 
addAll(int, Collection) - Method in class org.apache.openjpa.util.ProxyVector
 
addAll(Collection) - Method in class org.apache.openjpa.util.ProxyVector
 
addAllAbsent(Collection) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
addAttribute(String, String) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
Add an attribute to the current group.
addBatch(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
addBatch() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
addBatch(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
addBatch() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
addBatch(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
addBeanField(BCClass, String, Class) - Method in class org.apache.openjpa.enhance.DynamicStorageGenerator
Add a bean field of the given name and type.
addBoolean(String) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
Add the given value to the set of configuration properties.
addClassConditions(Select, boolean, Joins) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
Add WHERE conditions to the given select limiting the returned results to our mapping type, possibly including subclasses.
addClassExtensionKeys(Collection) - Method in class org.apache.openjpa.jdbc.meta.MetaDataPlusMappingFactory
 
addClassExtensionKeys(Collection) - Method in class org.apache.openjpa.meta.AbstractMetaDataFactory
 
addClassExtensionKeys(Collection) - Method in class org.apache.openjpa.meta.DelegatingMetaDataFactory
 
addClassExtensionKeys(Collection) - Method in interface org.apache.openjpa.meta.MetaDataFactory
Add any extension keys used by this instance to the given set.
addClassExtensionKeys(Collection) - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
addClassLoader(ClassLoader) - Method in class org.apache.openjpa.lib.util.MultiClassLoader
Add the given class loader to the set of loaders that will be tried.
addClassLoader(int, ClassLoader) - Method in class org.apache.openjpa.lib.util.MultiClassLoader
Add the given class loader at the specified index.
addClassLoader(ClassLoader) - Method in class org.apache.openjpa.util.MultiLoaderClassResolver
 
addClassLoaders(int, MultiClassLoader) - Method in class org.apache.openjpa.lib.util.MultiClassLoader
Adds all class loaders from the given multi loader starting at the given index.
addClassLoaders(MultiClassLoader) - Method in class org.apache.openjpa.lib.util.MultiClassLoader
Adds all the class loaders from the given multi loader.
addClassMappingAttributes(ClassMetaData) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Add mapping attributes for the given class.
addColumn(Column) - Method in class org.apache.openjpa.jdbc.schema.LocalConstraint
Add a column to the constraint.
addColumn(Column) - Method in class org.apache.openjpa.jdbc.schema.PrimaryKey
 
addColumn(Column) - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Add the given column to the database schema.
addColumn(String) - Method in class org.apache.openjpa.jdbc.schema.Table
Add a column to the table.
addColumnResult(Object) - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping
Add the id of a mapped column in the query result.
addComments(Object) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Add current comments to the given entity.
addComments(String[]) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
Add a comment to the stream.
addComments(Object) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
Write the given entity's comments.
addCommments(Object) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer
 
addConstraints(ValueMapping) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Add existing unique constraints and indexes to the given value.
addDeclaredFetchGroup(String) - Method in class org.apache.openjpa.meta.ClassMetaData
Adds fetch group of the given name, or returns existing instance.
addDeclaredField(String, Class) - Method in class org.apache.openjpa.meta.ClassMetaData
Add a new field metadata to this class.
addDeclaredFieldMapping(String, Class) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Convenience method to perform cast from ClassMetaData.addDeclaredField(java.lang.String, java.lang.Class).
addDeclaredInclude(String) - Method in class org.apache.openjpa.meta.FetchGroup
Includes given fetch group within this receiver.
addDeclaredInterface(Class) - Method in class org.apache.openjpa.meta.ClassMetaData
Explicitly declare the given interface among the ones this class implements.
addDecorator(ConnectionDecorator) - Method in class org.apache.openjpa.lib.jdbc.DecoratingDataSource
Add a connection decorator.
addDecorators(Collection) - Method in class org.apache.openjpa.lib.jdbc.DecoratingDataSource
Add multiple connection decorators efficiently.
addDefaultConstructor - Variable in class org.apache.openjpa.enhance.PCEnhancer.Flags
 
addDefinedSuperclassField(String, Class, Class) - Method in class org.apache.openjpa.meta.ClassMetaData
Add a new defined superclass field metadata to this class.
addDouble(String) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
Add the given value to the set of configuration properties.
added(Object) - Method in class org.apache.openjpa.util.AbstractChangeTracker
Notify the tracker that the given object was added.
added(Object) - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
added(Object, Object) - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
added(Object) - Method in interface org.apache.openjpa.util.CollectionChangeTracker
Record that the given element was added.
added(Object) - Method in class org.apache.openjpa.util.CollectionChangeTrackerImpl
 
added(Object, Object) - Method in interface org.apache.openjpa.util.MapChangeTracker
Record that the given entry was added to the map.
added(Object, Object) - Method in class org.apache.openjpa.util.MapChangeTrackerImpl
 
addElement(Object) - Method in class org.apache.openjpa.util.ProxyVector
 
addEmbeddedMetaData() - Method in class org.apache.openjpa.meta.FieldMetaData
 
addEmbeddedMetaData() - Method in interface org.apache.openjpa.meta.ValueMetaData
Add embedded metadata for this value.
addEmbeddedMetaData() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
addException(Collection, Exception) - Method in class org.apache.openjpa.jdbc.kernel.AbstractUpdateManager
Add the given exception to the given list, which may start out as null.
addExpirationListener(ExpirationListener) - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
addExpirationListener(ExpirationListener) - Method in interface org.apache.openjpa.datacache.DataCache
Add a new expiration event listener to this cache.
addExpirationListener(ExpirationListener) - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
addExtension(String, Object) - Method in class org.apache.openjpa.meta.Extensions
Add a vendor extension to this entity.
addExtension(String, String, Object) - Method in class org.apache.openjpa.meta.Extensions
Add a vendor extension to this entity.
addExtensionKeys(Collection) - Method in class org.apache.openjpa.meta.ClassMetaData
 
addExtensionKeys(Collection) - Method in class org.apache.openjpa.meta.Extensions
Add all the known extension keys to the specified collection; any implementation that utilized new extensions should override this method to include both the known extensions of its superclass as well as its own extension keys.
addExtensionKeys(Collection) - Method in class org.apache.openjpa.meta.FieldMetaData
 
addFetchGroup(String) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
addFetchGroup(String) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Adds group to the set of fetch group names to use when loading objects.
addFetchGroup(String) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
addFetchGroup(String) - Method in interface org.apache.openjpa.persistence.FetchPlan
Adds group to the set of fetch group to use when loading objects.
addFetchGroup(String) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
addFetchGroups(Collection) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
addFetchGroups(Collection) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Adds groups to the set of fetch group names to use when loading objects.
addFetchGroups(Collection) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
addFetchGroups(String...) - Method in interface org.apache.openjpa.persistence.FetchPlan
Adds groups to the set of fetch group names to use when loading objects.
addFetchGroups(Collection) - Method in interface org.apache.openjpa.persistence.FetchPlan
Adds groups to the set of fetch group names to use when loading objects.
addFetchGroups(String...) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
addFetchGroups(Collection) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
addField(String) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
addField(String) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Adds field to the set of fully-qualified field names to use when loading objects.
addField(String) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
addField(String) - Method in interface org.apache.openjpa.persistence.FetchPlan
Adds field to the set of fully-qualified field names to use when loading objects.
addField(Class, String) - Method in interface org.apache.openjpa.persistence.FetchPlan
Adds field to the set of field names to use when loading objects.
addField(String) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
addField(Class, String) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
addFieldExtensionKeys(Collection) - Method in class org.apache.openjpa.jdbc.meta.MetaDataPlusMappingFactory
 
addFieldExtensionKeys(Collection) - Method in class org.apache.openjpa.meta.AbstractMetaDataFactory
 
addFieldExtensionKeys(Collection) - Method in class org.apache.openjpa.meta.DelegatingMetaDataFactory
 
addFieldExtensionKeys(Collection) - Method in interface org.apache.openjpa.meta.MetaDataFactory
Add any extension keys used by this instance to the given set.
addFieldExtensionKeys(Collection) - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
addFieldMappingAttributes(FieldMetaData, FieldMetaData) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Add mapping attributes for the given field.
addFields(Collection) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
addFields(Collection) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Adds fields to the set of fully-qualified field names to use when loading objects.
addFields(Collection) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
addFields(String...) - Method in interface org.apache.openjpa.persistence.FetchPlan
Adds fields to the set of fully-qualified field names to use when loading objects.
addFields(Class, String...) - Method in interface org.apache.openjpa.persistence.FetchPlan
Adds fields to the set of field names to use when loading objects.
addFields(Collection) - Method in interface org.apache.openjpa.persistence.FetchPlan
Adds fields to the set of fully-qualified field names to use when loading objects.
addFields(Class, Collection) - Method in interface org.apache.openjpa.persistence.FetchPlan
Adds fields to the set of field names to use when loading objects.
addFields(String...) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
addFields(Class, String...) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
addFields(Collection) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
addFields(Class, Collection) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
addFile(String) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
Add the given value to the set of configuration properties.
addFileset(FileSet) - Method in class org.apache.openjpa.lib.ant.AbstractTask
 
addFilterListener(FilterListener) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
addFilterListener(FilterListener) - Method in interface org.apache.openjpa.kernel.Query
Register a filter listener for the query.
addFilterListener(FilterListener) - Method in class org.apache.openjpa.kernel.QueryImpl
 
addFilterListener(FilterListener) - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Register a filter listener for the query.
addFilterListener(FilterListener) - Method in class org.apache.openjpa.persistence.QueryImpl
 
addFirst(Object) - Method in class org.apache.openjpa.util.ProxyLinkedList
 
addForeignKey(ForeignKey) - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Add the given foreign key to the database schema.
addForeignKey() - Method in class org.apache.openjpa.jdbc.schema.Table
Add a foreign key to the table.
addForeignKey(String) - Method in class org.apache.openjpa.jdbc.schema.Table
Add a foreign key to the table.
addHint(String, Object) - Method in class org.apache.openjpa.meta.QueryMetaData
Add a query hint.
addIfAbsent(Object) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
addIndex(String) - Method in class org.apache.openjpa.jdbc.schema.Table
Add an index to the table.
addInt(String) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
Add the given value to the set of configuration properties.
addIterator(MetaDataIterator) - Method in class org.apache.openjpa.lib.meta.MetaDataIteratorChain
Add an iterator to the chain.
addJarFile(URL) - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
addJarFileName(String) - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
addJoin(String) - Method in class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
 
addJoin(String) - Method in interface org.apache.openjpa.jdbc.kernel.JDBCFetchConfiguration
Adds field to the set of fully-qualified field names to eagerly join when loading objects.
addJoin(String) - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
addJoinClassConditions() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
addJoinClassConditions() - Method in interface org.apache.openjpa.jdbc.sql.Select
Apply class conditions from relation joins.
addJoinClassConditions() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
addJoinConstraints(FieldMapping) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Add existing unique constraints and indexes to the given field's join.
addJoins(Collection) - Method in class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
 
addJoins(Collection) - Method in interface org.apache.openjpa.jdbc.kernel.JDBCFetchConfiguration
Adds fields to the set of fully-qualified field names to eagerly join when loading objects.
addJoins(Collection) - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
addLast(Object) - Method in class org.apache.openjpa.util.ProxyLinkedList
 
addLifecycleListener(Object, Class[]) - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
 
addLifecycleListener(Object, Class[]) - Method in interface org.apache.openjpa.kernel.Broker
Register a listener for lifecycle-related events on the specified classes.
addLifecycleListener(Object, Class[]) - Method in interface org.apache.openjpa.kernel.BrokerFactory
Register a listener for lifecycle-related events on the specified classes.
addLifecycleListener(Object, Class[]) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
addLifecycleListener(Object, Class[]) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
addLifecycleListener(Object, Class[]) - Method in class org.apache.openjpa.kernel.DelegatingBrokerFactory
 
addLifecycleListener(Object, Class...) - Method in class org.apache.openjpa.persistence.EntityManagerFactoryImpl
 
addLifecycleListener(Object, Class...) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
addLifecycleListener(Object, Class...) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Register a listener for lifecycle-related events on the specified classes.
addLifecycleListener(Object, Class...) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManagerFactory
Register a listener for lifecycle-related events on the specified classes.
addLifecycleListeners(BrokerImpl) - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
Add factory-registered lifecycle listeners to the broker.
addListener(Object, Class[]) - Method in class org.apache.openjpa.event.LifecycleEventManager
Register a lifecycle listener for the given classes.
addListener(RemoteCommitListener) - Method in class org.apache.openjpa.event.RemoteCommitEventManager
 
addListener(Object) - Method in class org.apache.openjpa.event.TransactionEventManager
 
addListener(SchemaGenerator.Listener) - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Adds a listener for schema generation events.
addListener(Object) - Method in class org.apache.openjpa.lib.util.AbstractEventManager
Register an event listener.
addListener(Object) - Method in class org.apache.openjpa.lib.util.concurrent.AbstractConcurrentEventManager
Register an event listener.
addListener(Object) - Method in interface org.apache.openjpa.lib.util.EventManager
Add an event listener.
addLogFactory(LogFactory) - Method in class org.apache.openjpa.lib.log.MultiLogFactory
 
addManagedClassName(String) - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
addMapping(String, Object) - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping.PCResult
Map the given path to the given result id.
addMapping(int, int, Object, Object) - Method in class org.apache.openjpa.lib.util.ReferenceHashMap
 
addMappingFileName(String) - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
addMetaData(ClassMetaData) - Method in interface org.apache.openjpa.meta.AbstractCFMetaDataFactory.Serializer
Add a class meta data to the set to be serialized.
addMetaData(Class) - Method in class org.apache.openjpa.meta.MetaDataRepository
Create a new metadata, populate it with default information, add it to the repository, and return it.
addMetaData(Class, int) - Method in class org.apache.openjpa.meta.MetaDataRepository
Create a new metadata, populate it with default information, add it to the repository, and return it.
addMetaData(ClassMetaData) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Add a class meta data to the set to be serialized.
addName(String, boolean) - Method in class org.apache.openjpa.jdbc.schema.NameSet
Attempt to add the given name to the set.
addNonMappedInterface(Class) - Method in class org.apache.openjpa.meta.MetaDataRepository
Add the given non-mapped interface to the repository.
addObject(String) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
Add the given value to the set of configuration properties.
addPCResult(Class) - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping
Add a mapped persistence-capable result with the given candidate type.
addPersistenceAware(Class) - Method in class org.apache.openjpa.meta.MetaDataRepository
Add the given class as persistence-aware.
addPlugin(String, boolean) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
Add the given value to the set of configuration properties.
addPluginList(String) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
Add the given value to the set of configuration properties.
addPrimaryKey(PrimaryKey) - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Add the given primary key to the database schema.
addPrimaryKey() - Method in class org.apache.openjpa.jdbc.schema.Table
Set the primary key for the table.
addPrimaryKey(String) - Method in class org.apache.openjpa.jdbc.schema.Table
Set the primary key for the table.
addPrimaryKeyColumn(Table) - Method in class org.apache.openjpa.jdbc.kernel.ClassTableJDBCSeq
 
addPrimaryKeyColumn(Table) - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
Add the primary key column to the given table and return it.
addPrimaryKeyColumn(Table) - Method in class org.apache.openjpa.jdbc.kernel.ValueTableJDBCSeq
 
addProperties(Map) - Method in interface org.apache.openjpa.lib.conf.ConfigurationProvider
Add the given properties to those in this provider, overwriting any exisitng properties under the same keys.
addProperties(Map) - Method in class org.apache.openjpa.lib.conf.MapConfigurationProvider
 
addProperty(String, Object) - Method in interface org.apache.openjpa.lib.conf.ConfigurationProvider
Add a single property, overwriting any existing property under the same key.
addProperty(String, Object) - Method in class org.apache.openjpa.lib.conf.MapConfigurationProvider
 
addPropertyChangeListener(PropertyChangeListener) - Method in interface org.apache.openjpa.lib.conf.Configuration
Adds a listener for any property changes.
addPropertyChangeListener(PropertyChangeListener) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
addProvider(ResourceBundleProvider) - Static method in class org.apache.openjpa.lib.util.Localizer
Register a resource provider.
addQueryMetaData(QueryMetaData) - Method in interface org.apache.openjpa.meta.AbstractCFMetaDataFactory.Serializer
Add a query meta data to the set to be serialized.
addQueryMetaData(Class, String) - Method in class org.apache.openjpa.meta.MetaDataRepository
Add a new query metadata to the repository and return it.
addQueryMetaData(QueryMetaData) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Add a query meta data to the set to be serialized.
addQueryResultMapping(Class, String) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Add a query result mapping.
addQueryResultMapping(QueryResultMapping) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer
Adds the given result set mapping to local cache.
addRegisterClassListener(PCRegistry.RegisterClassListener) - Static method in class org.apache.openjpa.enhance.PCRegistry
Register a PCRegistry.RegisterClassListener.
addResult(Object) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Add a result to be returned from the current parse.
addSchema(ClassMapping, SchemaGroup) - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSeq
No-op.
addSchema(ClassMapping, SchemaGroup) - Method in interface org.apache.openjpa.jdbc.kernel.JDBCSeq
Add any tables, etc needed by this factory for the given mapping to the given schema group, if they do not exist already.
addSchema(ClassMapping, SchemaGroup) - Method in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
 
addSchema(ClassMapping, SchemaGroup) - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
 
addSchema() - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Add a schema to the group.
addSchema(String) - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Add a schema to the group.
addSequence(String) - Method in class org.apache.openjpa.jdbc.schema.Schema
Add a sequence to the schema.
addSequence(Sequence) - Method in class org.apache.openjpa.jdbc.schema.XMLSchemaSerializer
 
addSequenceMetaData(SequenceMetaData) - Method in interface org.apache.openjpa.meta.AbstractCFMetaDataFactory.Serializer
Add a sequence meta data to the set to be serialized.
addSequenceMetaData(String) - Method in class org.apache.openjpa.meta.MetaDataRepository
Add a new sequence metadata to the repository and return it.
addSequenceMetaData(SequenceMetaData) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Add a sequence meta data to the set to be serialized.
addStandardProperties(StringBuffer) - Method in class org.apache.openjpa.jdbc.meta.SequenceMapping
 
addStandardProperties(StringBuffer) - Method in class org.apache.openjpa.meta.SequenceMetaData
Add standard properties to the given properties buffer.
addStrategyMappingAttributes(FieldMetaData) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Set mapping attributes for strategy.
addString(String) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
Add the given value to the set of configuration properties.
addStringList(String) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
Add the given value to the set of configuration properties.
addSystemListener(Object) - Method in class org.apache.openjpa.meta.MetaDataRepository
Add the given system lifecycle listener.
addSystemMappingElements(Collection) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer
 
addSystemMappingElements(Collection) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Add system-level mapping elements to be serialized.
addTable(String) - Method in class org.apache.openjpa.jdbc.schema.Schema
Add a table to the schema.
addTable(Table) - Method in interface org.apache.openjpa.jdbc.schema.SchemaSerializer
Add the given table to the set of tables that will be serialized.
addTable(Table) - Method in class org.apache.openjpa.jdbc.schema.XMLSchemaSerializer
 
addText(String) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
Add text to the current element.
addToCollection(OpenJPAStateManager, FieldMetaData, Object) - Method in class org.apache.openjpa.kernel.InverseManager
Add the given value to the collection at the selected field.
addTransactionListener(Object) - Method in interface org.apache.openjpa.kernel.Broker
Register a listener for transaction-related events.
addTransactionListener(Object) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
addTransactionListener(Object) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
addTransactionListener(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
addTransactionListener(Object) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Register a listener for transaction-related events.
addTransformer(ClassTransformer) - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
addTypesChangedListener(TypesChangedListener) - Method in class org.apache.openjpa.datacache.AbstractQueryCache
 
addTypesChangedListener(TypesChangedListener) - Method in class org.apache.openjpa.datacache.DelegatingQueryCache
 
addTypesChangedListener(TypesChangedListener) - Method in interface org.apache.openjpa.datacache.QueryCache
Add a new types event listener to this cache.
addUnique(String) - Method in class org.apache.openjpa.jdbc.schema.Table
Add a unique constraint to the table.
addValue(Value) - Method in interface org.apache.openjpa.lib.conf.Configuration
Add the given value to the set of configuration properties.
addValue(Value) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
addVersionMethods(BCClass) - Method in class org.apache.openjpa.enhance.PCDataGenerator
Add methods for loading and storing version data.
AFTER_ATTACH - Static variable in class org.apache.openjpa.event.LifecycleEvent
Event type when an instance is attached.
AFTER_BEGIN - Static variable in class org.apache.openjpa.event.TransactionEvent
Event type signifying that a transaction has just begun.
AFTER_CLEAR - Static variable in class org.apache.openjpa.event.LifecycleEvent
Event type when an instance is cleared.
AFTER_COMMIT - Static variable in class org.apache.openjpa.event.TransactionEvent
Event type signifying that the transaction has committed.
AFTER_COMMIT - Static variable in class org.apache.openjpa.lib.jdbc.JDBCEvent
Type code indicating that a Connection was just committed.
AFTER_COMMIT_COMPLETE - Static variable in class org.apache.openjpa.event.TransactionEvent
Event type signifying that the commit has completey ended and the transaction is no longer active.
AFTER_CONNECT - Static variable in class org.apache.openjpa.lib.jdbc.JDBCEvent
Type code indicating that a connection was obtained.
AFTER_CREATE_STATEMENT - Static variable in class org.apache.openjpa.lib.jdbc.JDBCEvent
Type code indicating that a Statement is being created.
AFTER_DELETE - Static variable in class org.apache.openjpa.event.LifecycleEvent
Event type when an instance is deleted.
AFTER_DETACH - Static variable in class org.apache.openjpa.event.LifecycleEvent
Event type when an instance is detached.
AFTER_DIRTY - Static variable in class org.apache.openjpa.event.LifecycleEvent
Event type when an instance is dirtied for the first time.
AFTER_DIRTY_FLUSHED - Static variable in class org.apache.openjpa.event.LifecycleEvent
Event type when an instance is dirtied for the first time after flush.
AFTER_EXECUTE_STATEMENT - Static variable in class org.apache.openjpa.lib.jdbc.JDBCEvent
Type code indicating that a Statement completed execution.
AFTER_FLUSH - Static variable in class org.apache.openjpa.event.TransactionEvent
Event type signifying that changes have been flushed to the datastore.
AFTER_LOAD - Static variable in class org.apache.openjpa.event.LifecycleEvent
Event type when an instance is loaded.
AFTER_PERSIST - Static variable in class org.apache.openjpa.event.LifecycleEvent
Event type when an instance is made persistent
AFTER_PREPARE_STATEMENT - Static variable in class org.apache.openjpa.lib.jdbc.JDBCEvent
Type code indicating that a Statement is being prepared.
AFTER_REFRESH - Static variable in class org.apache.openjpa.event.LifecycleEvent
Event type when an instances is refreshed.
AFTER_ROLLBACK - Static variable in class org.apache.openjpa.event.TransactionEvent
Event type signifying that the transaction was rolled back.
AFTER_ROLLBACK - Static variable in class org.apache.openjpa.lib.jdbc.JDBCEvent
Type code indicating that a rollback just occured.
AFTER_ROLLBACK_COMPLETE - Static variable in class org.apache.openjpa.event.TransactionEvent
Event type signifying that the rollback has completey ended and the transaction is no longer active.
AFTER_STATE_TRANSITIONS - Static variable in class org.apache.openjpa.event.TransactionEvent
Event type signifying that all state transitions have been made.
AFTER_STORE - Static variable in class org.apache.openjpa.event.LifecycleEvent
Event type when an instance is stored.
afterAttach(LifecycleEvent) - Method in interface org.apache.openjpa.event.AttachListener
Invoked after the instance has been attached.
afterBegin(TransactionEvent) - Method in class org.apache.openjpa.event.AbstractTransactionListener
 
afterBegin(TransactionEvent) - Method in interface org.apache.openjpa.event.BeginTransactionListener
Notification that a transaction has begun.
afterClear(LifecycleEvent) - Method in class org.apache.openjpa.event.AbstractLifecycleListener
 
afterClear(LifecycleEvent) - Method in interface org.apache.openjpa.event.ClearListener
Invoked after state is cleared.
afterCommit(RemoteCommitEvent) - Method in class org.apache.openjpa.datacache.AbstractDataCache
This method is part of the RemoteCommitListener interface.
afterCommit(RemoteCommitEvent) - Method in class org.apache.openjpa.datacache.AbstractQueryCache
This method is part of the RemoteCommitListener interface.
afterCommit(TransactionEvent) - Method in class org.apache.openjpa.event.AbstractTransactionListener
 
afterCommit(TransactionEvent) - Method in interface org.apache.openjpa.event.EndTransactionListener
Notification that a transaction has successfully committed.
afterCommit(TransactionEvent) - Method in class org.apache.openjpa.event.RemoteCommitEventManager
 
afterCommit(RemoteCommitEvent) - Method in interface org.apache.openjpa.event.RemoteCommitListener
Notification that a transaction associated with a different BrokerFactory has successfully committed.
afterCommit(JDBCEvent) - Method in class org.apache.openjpa.lib.jdbc.AbstractJDBCListener
 
afterCommit(JDBCEvent) - Method in interface org.apache.openjpa.lib.jdbc.JDBCListener
 
afterCommitComplete(TransactionEvent) - Method in class org.apache.openjpa.event.AbstractTransactionListener
 
afterCommitComplete(TransactionEvent) - Method in interface org.apache.openjpa.event.EndTransactionListener
Notification that a transaction has successfully committed and the transaction is no longer active.
afterCommitComplete(TransactionEvent) - Method in class org.apache.openjpa.event.RemoteCommitEventManager
 
afterCompletion(int) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
afterCompletion(int) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
afterConnect(JDBCEvent) - Method in class org.apache.openjpa.lib.jdbc.AbstractJDBCListener
 
afterConnect(JDBCEvent) - Method in interface org.apache.openjpa.lib.jdbc.JDBCListener
 
afterCreateStatement(JDBCEvent) - Method in class org.apache.openjpa.lib.jdbc.AbstractJDBCListener
 
afterCreateStatement(JDBCEvent) - Method in interface org.apache.openjpa.lib.jdbc.JDBCListener
 
afterDelete(LifecycleEvent) - Method in class org.apache.openjpa.event.AbstractLifecycleListener
 
afterDelete(LifecycleEvent) - Method in interface org.apache.openjpa.event.DeleteListener
Invoked after the instance transferred to a deleted state.
afterDetach(LifecycleEvent) - Method in interface org.apache.openjpa.event.DetachListener
Invoked after the instance has been detached.
afterDirty(LifecycleEvent) - Method in class org.apache.openjpa.event.AbstractLifecycleListener
 
afterDirty(LifecycleEvent) - Method in interface org.apache.openjpa.event.DirtyListener
Invoked after the first change is applied.
afterDirtyFlushed(LifecycleEvent) - Method in class org.apache.openjpa.event.AbstractLifecycleListener
 
afterDirtyFlushed(LifecycleEvent) - Method in interface org.apache.openjpa.event.DirtyListener
Invoked after the first change is applied to a flushed instance.
afterExecuteStatement(JDBCEvent) - Method in class org.apache.openjpa.lib.jdbc.AbstractJDBCListener
 
afterExecuteStatement(JDBCEvent) - Method in interface org.apache.openjpa.lib.jdbc.JDBCListener
 
afterFlush(TransactionEvent) - Method in class org.apache.openjpa.event.AbstractTransactionListener
 
afterFlush(TransactionEvent) - Method in interface org.apache.openjpa.event.FlushTransactionListener
Notification that a transaction has flushed all object changes.
afterLast() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
afterLoad(LifecycleEvent) - Method in class org.apache.openjpa.event.AbstractLifecycleListener
 
afterLoad(LifecycleEvent) - Method in interface org.apache.openjpa.event.LoadListener
Invoked after state has been loaded into the instance.
afterLoad(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractVersionStrategy
 
afterLoad(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy
 
afterLoad(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.SuperclassVersionStrategy
 
afterLoad(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.Version
 
afterLoad(OpenJPAStateManager, JDBCStore) - Method in interface org.apache.openjpa.jdbc.meta.VersionStrategy
This method is called after data is loaded into the instance, in case the version indicator works off of a state image.
afterPersist(LifecycleEvent) - Method in class org.apache.openjpa.event.AbstractLifecycleListener
 
afterPersist(LifecycleEvent) - Method in interface org.apache.openjpa.event.PersistListener
Invoked when an instance is persisted.
afterPrepareStatement(JDBCEvent) - Method in class org.apache.openjpa.lib.jdbc.AbstractJDBCListener
 
afterPrepareStatement(JDBCEvent) - Method in interface org.apache.openjpa.lib.jdbc.JDBCListener
 
afterRefresh(LifecycleEvent) - Method in interface org.apache.openjpa.event.LoadListener
Invoked after state has been refreshed.
afterReturn(JDBCEvent) - Method in class org.apache.openjpa.lib.jdbc.AbstractJDBCListener
 
afterRollback(TransactionEvent) - Method in class org.apache.openjpa.event.AbstractTransactionListener
 
afterRollback(TransactionEvent) - Method in interface org.apache.openjpa.event.EndTransactionListener
Notification that a transaction has been rolled back.
afterRollback(TransactionEvent) - Method in class org.apache.openjpa.event.RemoteCommitEventManager
 
afterRollback(JDBCEvent) - Method in class org.apache.openjpa.lib.jdbc.AbstractJDBCListener
 
afterRollback(JDBCEvent) - Method in interface org.apache.openjpa.lib.jdbc.JDBCListener
 
afterRollbackComplete(TransactionEvent) - Method in class org.apache.openjpa.event.AbstractTransactionListener
 
afterRollbackComplete(TransactionEvent) - Method in interface org.apache.openjpa.event.EndTransactionListener
Notification that a transaction has been rolled back and the transaction is no longer active.
afterRollbackComplete(TransactionEvent) - Method in class org.apache.openjpa.event.RemoteCommitEventManager
 
afterSection() - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
afterSpecificationSet(Configuration) - Method in class org.apache.openjpa.lib.conf.AbstractProductDerivation
 
afterSpecificationSet(Configuration) - Method in interface org.apache.openjpa.lib.conf.ProductDerivation
Called after the specification has been set.
afterSpecificationSet(Configuration) - Static method in class org.apache.openjpa.lib.conf.ProductDerivations
Apply ProductDerivation.afterSpecificationSet(org.apache.openjpa.lib.conf.Configuration) callbacks to the the given instance.
afterSpecificationSet(Configuration) - Method in class org.apache.openjpa.persistence.jdbc.JDBCPersistenceProductDerivation
 
afterSpecificationSet(Configuration) - Method in class org.apache.openjpa.persistence.PersistenceProductDerivation
 
afterStateTransitions(TransactionEvent) - Method in class org.apache.openjpa.event.AbstractTransactionListener
 
afterStateTransitions(TransactionEvent) - Method in interface org.apache.openjpa.event.EndTransactionListener
Notification that state transitions are complete.
afterStateTransitions(TransactionEvent) - Method in class org.apache.openjpa.event.RemoteCommitEventManager
 
afterStore(LifecycleEvent) - Method in class org.apache.openjpa.event.AbstractLifecycleListener
 
afterStore(LifecycleEvent) - Method in interface org.apache.openjpa.event.StoreListener
Invoked just after store.
AggregateListener - Interface in org.apache.openjpa.kernel.exps
An aggregate listener aggregates data produced by an ExpressionQuery.
aggregateListenerPlugins - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
ALIAS - Static variable in class org.apache.openjpa.jdbc.meta.strats.ClassNameDiscriminatorStrategy
 
ALIAS - Static variable in class org.apache.openjpa.jdbc.meta.strats.FlatClassStrategy
 
ALIAS - Static variable in class org.apache.openjpa.jdbc.meta.strats.FullClassStrategy
 
ALIAS - Static variable in class org.apache.openjpa.jdbc.meta.strats.NoneClassStrategy
 
ALIAS - Static variable in class org.apache.openjpa.jdbc.meta.strats.NoneDiscriminatorStrategy
 
ALIAS - Static variable in class org.apache.openjpa.jdbc.meta.strats.NoneFieldStrategy
 
ALIAS - Static variable in class org.apache.openjpa.jdbc.meta.strats.NoneVersionStrategy
 
ALIAS - Static variable in class org.apache.openjpa.jdbc.meta.strats.NumberVersionStrategy
 
ALIAS - Static variable in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy
 
ALIAS - Static variable in class org.apache.openjpa.jdbc.meta.strats.SubclassJoinDiscriminatorStrategy
 
ALIAS - Static variable in class org.apache.openjpa.jdbc.meta.strats.TimestampVersionStrategy
 
ALIAS - Static variable in class org.apache.openjpa.jdbc.meta.strats.ValueMapDiscriminatorStrategy
 
ALIAS - Static variable in class org.apache.openjpa.jdbc.meta.strats.VerticalClassStrategy
 
alias - Variable in class org.apache.openjpa.kernel.exps.QueryExpressions
 
alias(String) - Method in class org.apache.openjpa.lib.conf.Value
Alias the given setting.
alias(String, String[], boolean) - Method in class org.apache.openjpa.lib.conf.Value
Alias the given setting.
ALIAS_EJB - Static variable in class org.apache.openjpa.persistence.PersistenceProductDerivation
 
ALIASES - Static variable in class org.apache.openjpa.persistence.EntityManagerFactoryValue
 
all(Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
all(Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return an expression representing the given condition.
all(Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
ALL_EVENTS - Static variable in class org.apache.openjpa.event.LifecycleEvent
Convenience array of all event types.
allocate(int, StoreContext, ClassMetaData) - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSeq
 
allocate(int, StoreContext, ClassMetaData) - Method in class org.apache.openjpa.kernel.DelegatingSeq
 
allocate(int, StoreContext, ClassMetaData) - Method in interface org.apache.openjpa.kernel.Seq
Allocate additional values efficiently.
allocate(int, StoreContext, ClassMetaData) - Method in class org.apache.openjpa.kernel.TimeSeededSeq
 
allocate(int, StoreContext, ClassMetaData) - Method in class org.apache.openjpa.kernel.UUIDHexSeq
 
allocate(int, StoreContext, ClassMetaData) - Method in class org.apache.openjpa.kernel.UUIDStringSeq
 
allocate(int) - Method in interface org.apache.openjpa.persistence.Generator
Hint to the sequence to allocate additional values up-front for efficiency.
allocate(int) - Method in class org.apache.openjpa.persistence.GeneratorImpl
 
allocateInternal(int, JDBCStore, ClassMapping) - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSeq
Allocate additional sequence values.
allocateInternal(int, JDBCStore, ClassMapping) - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
 
allowConcurrentRead - Variable in class org.apache.openjpa.jdbc.sql.EmpressDictionary
This setting inserts "BYPASS" after every "SELECT".
allowsAliasInBulkClause - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
allProceduresAreCallable() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
allSequencesFromOneSchemaSQL - Variable in class org.apache.openjpa.jdbc.sql.PostgresDictionary
SQL statement to load schema,name pairs from a named schema.
allSequencesSQL - Variable in class org.apache.openjpa.jdbc.sql.PostgresDictionary
SQL statement to load all sequence schema,name pairs from all schemas.
allTablesAreSelectable() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
and(Expression, Expression) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
and(Joins, Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
and(Joins, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
AND the given joins together.
and(Joins, Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
and(Expression, Expression) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return the two expressions AND'd together.
and(Expression, Expression) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
AnnotationPersistenceMappingParser - Class in org.apache.openjpa.persistence.jdbc
Persistence annotation mapping parser.
AnnotationPersistenceMappingParser(JDBCConfiguration) - Constructor for class org.apache.openjpa.persistence.jdbc.AnnotationPersistenceMappingParser
 
AnnotationPersistenceMetaDataParser - Class in org.apache.openjpa.persistence
Persistence annotation metadata parser.
AnnotationPersistenceMetaDataParser(OpenJPAConfiguration) - Constructor for class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Constructor; supply configuration.
any(Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
any(Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return an expression representing the given condition.
any(Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
append(SQLBuffer, Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
append(SQLBuffer, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
Append the given joins to the given buffer.
append(SQLBuffer, Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
append(SQLBuffer) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Append all SQL and parameters of the given buffer.
append(Table) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
 
append(Sequence) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
 
append(Column) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
 
append(String) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
 
append(Select, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Append a subselect.
APPEND - Static variable in interface org.apache.openjpa.lib.meta.MetaDataSerializer
 
append(boolean) - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
append(byte) - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
append(char) - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
append(double) - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
append(float) - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
append(int) - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
append(long) - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
append(short) - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
append(Object) - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
append(String) - Method in class org.apache.openjpa.lib.util.ParameterTemplate
Add the given value to the internal template.
append(boolean) - Method in class org.apache.openjpa.lib.util.ParameterTemplate
Add the given value to the internal template.
append(char) - Method in class org.apache.openjpa.lib.util.ParameterTemplate
Add the given value to the internal template.
append(double) - Method in class org.apache.openjpa.lib.util.ParameterTemplate
Add the given value to the internal template.
append(float) - Method in class org.apache.openjpa.lib.util.ParameterTemplate
Add the given value to the internal template.
append(int) - Method in class org.apache.openjpa.lib.util.ParameterTemplate
Add the given value to the internal template.
append(long) - Method in class org.apache.openjpa.lib.util.ParameterTemplate
Add the given value to the internal template.
append(short) - Method in class org.apache.openjpa.lib.util.ParameterTemplate
Add the given value to the internal template.
append(Object) - Method in class org.apache.openjpa.lib.util.ParameterTemplate
Add the given value to the internal template.
append(InputStream) - Method in class org.apache.openjpa.lib.util.ParameterTemplate
Add the given value to the internal template.
append(Reader) - Method in class org.apache.openjpa.lib.util.ParameterTemplate
Add the given value to the internal template.
append(File) - Method in class org.apache.openjpa.lib.util.ParameterTemplate
Add the given value to the internal template.
appendCast(SQLBuffer, FilterValue, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Cast the specified value to the specified type.
appendCount(Select, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Append a subselect count.
appendInfo(StringBuffer) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
appendInfo(StringBuffer) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
appendInfo(StringBuffer) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDataSource
 
appendInfo(StringBuffer) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
appendInfo(StringBuffer) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
appendInfo(StringBuffer) - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
appendIsEmpty(Select, ExpContext, ExpState, SQLBuffer) - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
 
appendIsEmpty(Select, ExpContext, ExpState, SQLBuffer) - Method in interface org.apache.openjpa.jdbc.kernel.exps.Val
Append the SQL testing whether this value is empty to the given buffer.
appendIsEmpty(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
appendIsEmpty(SQLBuffer, Select, Joins) - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Append a where clause to the given statement checking if this value is empty.
appendIsEmpty(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
appendIsEmpty(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.ContainerFieldStrategy
 
appendIsNotEmpty(Select, ExpContext, ExpState, SQLBuffer) - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
 
appendIsNotEmpty(Select, ExpContext, ExpState, SQLBuffer) - Method in interface org.apache.openjpa.jdbc.kernel.exps.Val
Append the SQL testing whether this value is not empty to the given buffer.
appendIsNotEmpty(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
appendIsNotEmpty(SQLBuffer, Select, Joins) - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Append a where clause to the given statement checking if this value is not empty.
appendIsNotEmpty(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
appendIsNotEmpty(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.ContainerFieldStrategy
 
appendIsNotNull(Select, ExpContext, ExpState, SQLBuffer) - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
 
appendIsNotNull(Select, ExpContext, ExpState, SQLBuffer) - Method in interface org.apache.openjpa.jdbc.kernel.exps.Val
Append the SQL testing whether this value is not null to the given buffer.
appendIsNotNull(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
appendIsNotNull(SQLBuffer, Select, Joins) - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Append a where clause to the given statement checking if this value is not null.
appendIsNotNull(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
appendIsNotNull(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.ContainerFieldStrategy
 
appendIsNotNull(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedFieldStrategy
 
appendIsNotNull(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
appendIsNotNull(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
appendIsNotNull(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
appendIsNotNull(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
appendIsNull(Select, ExpContext, ExpState, SQLBuffer) - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
 
appendIsNull(Select, ExpContext, ExpState, SQLBuffer) - Method in interface org.apache.openjpa.jdbc.kernel.exps.Val
Append the SQL testing whether this value is null to the given buffer.
appendIsNull(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
appendIsNull(SQLBuffer, Select, Joins) - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Append a where clause to the given statement checking if this value is null.
appendIsNull(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
appendIsNull(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.ContainerFieldStrategy
 
appendIsNull(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedFieldStrategy
 
appendIsNull(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
appendIsNull(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
appendIsNull(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
appendIsNull(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
appendJoinCount(SQLBuffer, Select, Joins, DBDictionary, FieldMapping, ForeignKey) - Static method in class org.apache.openjpa.jdbc.meta.strats.ContainerFieldStrategy
 
appendNumericCast(SQLBuffer, FilterValue) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Append SQL for the given numeric value to the buffer, casting as needed.
appendOpenJPABanner(StringBuffer) - Method in class org.apache.openjpa.conf.OpenJPAVersion
 
appendProperty(StringBuffer, String, String) - Method in class org.apache.openjpa.meta.SequenceMetaData
Add a string property to the buffer.
appendProperty(StringBuffer, String, int) - Method in class org.apache.openjpa.meta.SequenceMetaData
Add an int property to the buffer.
appendSelectRange(SQLBuffer, long, long) - Method in class org.apache.openjpa.jdbc.sql.AbstractSQLServerDictionary
 
appendSelectRange(SQLBuffer, long, long) - Method in class org.apache.openjpa.jdbc.sql.DB2Dictionary
 
appendSelectRange(SQLBuffer, long, long) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
If this dictionary can select ranges, use this method to append the range SQL.
appendSelectRange(SQLBuffer, long, long) - Method in class org.apache.openjpa.jdbc.sql.HSQLDictionary
 
appendSelectRange(SQLBuffer, long, long) - Method in class org.apache.openjpa.jdbc.sql.MySQLDictionary
 
appendSelectRange(SQLBuffer, long, long) - Method in class org.apache.openjpa.jdbc.sql.PostgresDictionary
 
appendSize(Select, ExpContext, ExpState, SQLBuffer) - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
 
appendSize(Select, ExpContext, ExpState, SQLBuffer) - Method in interface org.apache.openjpa.jdbc.kernel.exps.Val
Append the SQL checking the size of this value.
appendSize(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
appendSize(SQLBuffer, Select, Joins) - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Append a where clause to the given statement checking the size of the value.
appendSize(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
appendSize(SQLBuffer, Select, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.ContainerFieldStrategy
 
appendSize(Column, String) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Helper method to add size properties to the specified type.
appendSize(Column, String) - Method in class org.apache.openjpa.jdbc.sql.FoxProDictionary
 
appendSize(Column, String) - Method in class org.apache.openjpa.jdbc.sql.InterbaseDictionary
 
appendTo(Select, ExpContext, ExpState, SQLBuffer, int) - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
 
appendTo(SQLBuffer) - Method in interface org.apache.openjpa.jdbc.kernel.exps.FilterValue
Append the first SQL element for this value to the given buffer.
appendTo(SQLBuffer, int) - Method in interface org.apache.openjpa.jdbc.kernel.exps.FilterValue
Append the indexth SQL element for this value to the given buffer.
appendTo(SQLBuffer, FilterValue, FilterValue[], ClassMapping, JDBCStore) - Method in class org.apache.openjpa.jdbc.kernel.exps.GetColumn
 
appendTo(SQLBuffer, FilterValue[], ClassMapping, JDBCStore) - Method in interface org.apache.openjpa.jdbc.kernel.exps.JDBCAggregateListener
Append the SQL for this aggregate.
appendTo(SQLBuffer, FilterValue, FilterValue[], ClassMapping, JDBCStore) - Method in interface org.apache.openjpa.jdbc.kernel.exps.JDBCFilterListener
Append the SQL for this expression or value.
appendTo(SQLBuffer, FilterValue, FilterValue[], ClassMapping, JDBCStore) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCStringContains
Deprecated.  
appendTo(SQLBuffer, FilterValue, FilterValue[], ClassMapping, JDBCStore) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCWildcardMatch
Deprecated.  
appendTo(SQLBuffer, FilterValue, FilterValue[], ClassMapping, JDBCStore) - Method in class org.apache.openjpa.jdbc.kernel.exps.SQLEmbed
 
appendTo(Select, ExpContext, ExpState, SQLBuffer, int) - Method in interface org.apache.openjpa.jdbc.kernel.exps.Val
Append the indexth SQL element to the given buffer.
appendUnaliasedJoin(SQLBuffer, Select, Joins, DBDictionary, FieldMapping, ForeignKey) - Static method in class org.apache.openjpa.jdbc.meta.strats.ContainerFieldStrategy
 
appendUpdates(Select, JDBCStore, SQLBuffer, Object[], Map, boolean) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
 
appendValue(Object) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Append a parameter value.
appendValue(Object, Column) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Append a parameter value for a specific column.
appendValue(boolean) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Append a parameter value.
appendValue(boolean, Column) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Append a parameter value.
appendValue(byte) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Append a parameter value.
appendValue(byte, Column) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Append a parameter value.
appendValue(char) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Append a parameter value.
appendValue(char, Column) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Append a parameter value.
appendValue(double) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Append a parameter value.
appendValue(double, Column) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Append a parameter value.
appendValue(float) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Append a parameter value.
appendValue(float, Column) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Append a parameter value.
appendValue(int) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Append a parameter value.
appendValue(int, Column) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Append a parameter value.
appendValue(long) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Append a parameter value.
appendValue(long, Column) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Append a parameter value.
appendValue(short) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Append a parameter value.
appendValue(short, Column) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Append a parameter value.
ApplicationIds - Class in org.apache.openjpa.util
Utility class for manipulating application object ids.
ApplicationIds() - Constructor for class org.apache.openjpa.util.ApplicationIds
 
ApplicationIdTool - Class in org.apache.openjpa.enhance
Generates a class appropriate for use as an application identity class.
ApplicationIdTool(OpenJPAConfiguration, Class) - Constructor for class org.apache.openjpa.enhance.ApplicationIdTool
Constructs a new ApplicationIdTool capable of generating an object id class for type.
ApplicationIdTool(OpenJPAConfiguration, Class, ClassMetaData) - Constructor for class org.apache.openjpa.enhance.ApplicationIdTool
Constructs a new tool instance capable of generating an object id class for meta.
ApplicationIdTool.Flags - Class in org.apache.openjpa.enhance
Run flags.
ApplicationIdTool.Flags() - Constructor for class org.apache.openjpa.enhance.ApplicationIdTool.Flags
 
ApplicationIdTool.ObjectIdLoader - Interface in org.apache.openjpa.enhance
Interface implemented by metadata factories that can load non-existant object id classes.
ApplicationIdToolTask - Class in org.apache.openjpa.ant
Executes the application id tool on the specified files.
ApplicationIdToolTask() - Constructor for class org.apache.openjpa.ant.ApplicationIdToolTask
Default constructor.
areAllPrimaryKeyColumns(Column[]) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Return whether all the given columns are primary key columns.
areRemoteEventsEnabled() - Method in class org.apache.openjpa.event.RemoteCommitEventManager
Return true if remote events are enabled.
Args - Class in org.apache.openjpa.jdbc.kernel.exps
A list of arguments to a multi-argument function.
Args(Val, Val) - Constructor for class org.apache.openjpa.jdbc.kernel.exps.Args
Constructor.
ArgumentException - Exception in org.apache.openjpa.persistence
Extended IllegalArgumentException.
ArgumentException(String, Throwable[], Object, boolean) - Constructor for exception org.apache.openjpa.persistence.ArgumentException
 
ArgumentException(Localizer.Message, Throwable[], Object, boolean) - Constructor for exception org.apache.openjpa.persistence.ArgumentException
 
Arguments - Interface in org.apache.openjpa.kernel.exps
Multiple arguments to a function call.
ARRAY - Static variable in class org.apache.openjpa.meta.JavaTypes
 
ArrayStateImage - Class in org.apache.openjpa.util
Utilities for dealing with a simple state image consisting of an Object[] of field values with one extra index containing a BitSet of loaded fields.
ArrayStateImage() - Constructor for class org.apache.openjpa.util.ArrayStateImage
 
arrayTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
ascending - Variable in class org.apache.openjpa.kernel.exps.QueryExpressions
 
ASCII_STREAM - Static variable in class org.apache.openjpa.jdbc.meta.JavaSQLTypes
 
asExpression(Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
asExpression(Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return the given value as an expression.
asExpression(Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
assertActiveTransaction() - Method in interface org.apache.openjpa.kernel.Broker
Throw an exception if there is no active transaction.
assertActiveTransaction() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
assertActiveTransaction() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
assertAllowedType(Object, Class) - Static method in class org.apache.openjpa.util.Proxies
Used by proxy types to check that an attempt to add a new value is legal.
assertFiles(String[]) - Method in class org.apache.openjpa.lib.ant.AbstractTask
Helper method to throw a standard exception if the task is not given any files to execute on.
assertJoinable(Column) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Return the joinable for the given column, or throw an exception if none is available.
assertJoinable(ValueMapping) - Static method in class org.apache.openjpa.jdbc.meta.strats.HandlerStrategies
Throw the proper exception if the given handler-controlled value represents an unjoinable relation.
assertNoForeignKey(MetaDataContext, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Assert that the user did not try to place a foreign key on this mapping.
assertNoIndex(MetaDataContext, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Assert that the user did not try to place an index on this mapping.
assertNoJoin(MetaDataContext, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Assert that the user did not try to join.
assertNontransactionalRead() - Method in interface org.apache.openjpa.kernel.Broker
Throw an exception if there is no transaction active and nontransactional reading is not enabled.
assertNontransactionalRead() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
assertNontransactionalRead() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
assertNoSchemaComponents(MetaDataContext, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Assert that the user did not supply any columns, index, unique constraint, or foreign key for this mapping.
assertNotMappedBy() - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
Throws an informative exception if the field declares a mapped-by value.
assertNotReadOnly() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
assertNotReadOnly() - Method in interface org.apache.openjpa.kernel.Query
Assert that the query is not read-only.
assertNotReadOnly() - Method in class org.apache.openjpa.kernel.QueryImpl
 
assertNotReadOnly() - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
Checks if the configuration is read only and if so throws an exception, otherwise returns silently.
assertNotSerialized() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
assertNotSerialized() - Method in interface org.apache.openjpa.kernel.Query
Check that the query has not been serialized, which causes it to lose its association with its Broker.
assertNotSerialized() - Method in class org.apache.openjpa.kernel.QueryImpl
 
assertNoUnique(MetaDataContext, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Assert that the user did not try to place a unique constraint on this mapping.
assertOpen() - Method in interface org.apache.openjpa.kernel.Broker
Throw an exception if this broker has been closed.
assertOpen() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
assertOpen() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
assertOpen() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
assertOpen() - Method in interface org.apache.openjpa.kernel.Query
Assert that the query's broker is still open.
assertOpen() - Method in class org.apache.openjpa.kernel.QueryImpl
 
assertOpen() - Method in class org.apache.openjpa.lib.rop.AbstractResultList
 
assertParameters(StoreQuery.Executor, Object[]) - Method in class org.apache.openjpa.kernel.QueryImpl
Checks that the passed parameters match the declarations.
assertPersistenceCapable(Object) - Method in class org.apache.openjpa.kernel.BrokerImpl
Return the given instance as a PersistenceCapable.
assertStrategy(MetaDataContext, Object, Object, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Assert that this info has the given strategy or no strategy.
assertSupport(boolean, String) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Assert that the given dictionary flag is true.
assertSupported(int, MetaDataContext, String) - Static method in class org.apache.openjpa.meta.ValueStrategies
Assert that the given strategy is supported by the current runtime.
assertUnboundVariablesValid() - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
Validate that all unbound variables are of a PC type.
assertWriteOperation() - Method in interface org.apache.openjpa.kernel.Broker
Throw an exception if a write operation is not permitted (there is no active transaction and nontransactional writing is not enabled).
assertWriteOperation() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
assertWriteOperation() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
assign(OpenJPAStateManager, StoreManager, boolean) - Static method in class org.apache.openjpa.util.ApplicationIds
Assign an application identity object to the given state, or return false if determining the application identity requires a flush.
assignDataStoreId(OpenJPAStateManager, Object) - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
Assign a new datastore identity to the given instance.
assignField(OpenJPAStateManager, int, boolean) - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
 
assignField(OpenJPAStateManager, int, boolean) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
assignField(OpenJPAStateManager, int, boolean) - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
assignField(OpenJPAStateManager, int, boolean) - Method in interface org.apache.openjpa.kernel.StoreManager
Assign a value to the given field.
assignObjectId(OpenJPAStateManager, boolean) - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
 
assignObjectId(OpenJPAStateManager, boolean) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
assignObjectId(OpenJPAStateManager, boolean) - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
assignObjectId(boolean) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
assignObjectId(boolean) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
assignObjectId(boolean) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
assignObjectId(boolean) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Ask the store manager to assign a permanent oid to this new instance.
assignObjectId(boolean) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
assignObjectId(OpenJPAStateManager, boolean) - Method in interface org.apache.openjpa.kernel.StoreManager
Assign an object id to the given new instance.
attach(Object, boolean, OpCallbacks) - Method in interface org.apache.openjpa.kernel.Broker
Import the specified detached object into the broker.
attach(Object, boolean, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
attach(Object, boolean, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
attach(AttachManager, Object, ClassMetaData, PersistenceCapable, OpenJPAStateManager, ValueMetaData, boolean) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
attachAll(Collection, boolean, OpCallbacks) - Method in interface org.apache.openjpa.kernel.Broker
Import the specified objects into the broker.
attachAll(Collection, boolean, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
attachAll(Collection, boolean, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
AttachListener - Interface in org.apache.openjpa.event
Listener for when a detached instance is attached.
ATTRIBUTE_ALLOWED_VALUES - Static variable in interface org.apache.openjpa.lib.conf.Configuration
Attribute of returned Value property descriptors listing recognized values for the property.
ATTRIBUTE_CATEGORY - Static variable in interface org.apache.openjpa.lib.conf.Configuration
Attribute of the returned Value property descriptors naming the property' hierarchical category.
ATTRIBUTE_INTERFACE - Static variable in interface org.apache.openjpa.lib.conf.Configuration
Attribute of the returned Value property descriptors naming the interface that plugin values for this property must implement.
ATTRIBUTE_ORDER - Static variable in interface org.apache.openjpa.lib.conf.Configuration
Attribute of the returned Value property descriptors naming the property's ordering in its category.
ATTRIBUTE_TYPE - Static variable in interface org.apache.openjpa.lib.conf.Configuration
Attribute of the returned Value property descriptors naming the property's type or category.
ATTRIBUTE_XML - Static variable in interface org.apache.openjpa.lib.conf.Configuration
Attribute of the returned Value property descriptors naming the property's name in XML format (i.e.
AUTOASSIGN - Static variable in class org.apache.openjpa.meta.ValueStrategies
"autoassigned" value strategy.
autoAssignClause - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
autoAssignSequenceName - Variable in class org.apache.openjpa.jdbc.sql.OracleDictionary
The global sequence name to use for autoassign simulation.
autoAssignTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
autoClear - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
AutoClear - Interface in org.apache.openjpa.kernel
State clearing constants.
autoDetach - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
AutoDetach - Interface in org.apache.openjpa.kernel
Bit flags for when to automatically detach the entire persistence context.
AutomaticManagedRuntime - Class in org.apache.openjpa.ee
Implementation of the ManagedRuntime interface that searches through a set of known JNDI locations and method invocations to locate the appropriate mechanism for obtaining a TransactionManager.
AutomaticManagedRuntime() - Constructor for class org.apache.openjpa.ee.AutomaticManagedRuntime
 
avg(Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
avg(Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return the average of the given value for all matches.
avg(Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
await() - Method in interface org.apache.openjpa.lib.util.concurrent.Condition
Causes the current thread to wait until it is signalled or interrupted.
await(long, TimeUnit) - Method in interface org.apache.openjpa.lib.util.concurrent.Condition
Causes the current thread to wait until it is signalled or interrupted, or the specified waiting time elapses.
awaitNanos(Condition, long) - Static method in class org.apache.openjpa.lib.util.concurrent.Utils
Causes the current thread to wait until it is signalled or interrupted, or the specified waiting time elapses.
awaitUninterruptibly() - Method in interface org.apache.openjpa.lib.util.concurrent.Condition
Causes the current thread to wait until it is signalled.
awaitUntil(Date) - Method in interface org.apache.openjpa.lib.util.concurrent.Condition
Causes the current thread to wait until it is signalled or interrupted, or the specified deadline elapses.

B

backingMember(Member) - Method in class org.apache.openjpa.meta.FieldMetaData
Supply the backing member object; this allows us to utilize parameterized type information if available.
backup(File, boolean) - Static method in class org.apache.openjpa.lib.util.Files
Backup the given file to a new file called <file-name>~.
backupAndDelete(Collection) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Backup and delete the source files for the given metadatas.
Base16Encoder - Class in org.apache.openjpa.lib.util
Base 16 encoder.
Base16Encoder() - Constructor for class org.apache.openjpa.lib.util.Base16Encoder
 
BeanLifecycleCallbacks - Class in org.apache.openjpa.event
Performs a callback method on a cached bean instance.
BeanLifecycleCallbacks(Class, String, boolean, Class) - Constructor for class org.apache.openjpa.event.BeanLifecycleCallbacks
Constructor.
BeanLifecycleCallbacks(Class, Method, boolean) - Constructor for class org.apache.openjpa.event.BeanLifecycleCallbacks
Constructor.
BEFORE_ATTACH - Static variable in class org.apache.openjpa.event.LifecycleEvent
Event type when an instance is attached.
BEFORE_CLEAR - Static variable in class org.apache.openjpa.event.LifecycleEvent
Event type when an instance is cleared.
BEFORE_CLOSE - Static variable in class org.apache.openjpa.lib.jdbc.JDBCEvent
Type code indicating that a connection was closed.
BEFORE_COMMIT - Static variable in class org.apache.openjpa.event.TransactionEvent
Event type signifying that the transaction is about to be committed.
BEFORE_COMMIT - Static variable in class org.apache.openjpa.lib.jdbc.JDBCEvent
Type code indicating that a Connection is about to be committed.
BEFORE_CREATE_STATEMENT - Static variable in class org.apache.openjpa.lib.jdbc.JDBCEvent
Type code indicating that a Statement is being created.
BEFORE_DELETE - Static variable in class org.apache.openjpa.event.LifecycleEvent
Event type when an instance is deleted.
BEFORE_DETACH - Static variable in class org.apache.openjpa.event.LifecycleEvent
Event type when an instance is detached.
BEFORE_DIRTY - Static variable in class org.apache.openjpa.event.LifecycleEvent
Event type when an instance is dirtied for the first time.
BEFORE_DIRTY_FLUSHED - Static variable in class org.apache.openjpa.event.LifecycleEvent
Event type when an instance is dirtied for the first time after flush.
BEFORE_EXECUTE_STATEMENT - Static variable in class org.apache.openjpa.lib.jdbc.JDBCEvent
Type code indicating that a Statement is about to be executed.
BEFORE_FLUSH - Static variable in class org.apache.openjpa.event.TransactionEvent
Event type signifying that changes are about to be flushed to the datastore.
BEFORE_PERSIST - Static variable in class org.apache.openjpa.event.LifecycleEvent
Event type before an instance is made persistent
BEFORE_PREPARE_STATEMENT - Static variable in class org.apache.openjpa.lib.jdbc.JDBCEvent
Type code indicating that a Statement is being prepared.
BEFORE_ROLLBACK - Static variable in class org.apache.openjpa.lib.jdbc.JDBCEvent
Type code indicating that a rollback is about to occur.
BEFORE_STORE - Static variable in class org.apache.openjpa.event.LifecycleEvent
Event type when an instance is stored.
beforeAccessField(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
Load the given field before access.
beforeAttach(LifecycleEvent) - Method in interface org.apache.openjpa.event.AttachListener
Invoked before the instance is attached.
beforeClear(LifecycleEvent) - Method in class org.apache.openjpa.event.AbstractLifecycleListener
 
beforeClear(LifecycleEvent) - Method in interface org.apache.openjpa.event.ClearListener
Invoked before state is cleared.
beforeClose(JDBCEvent) - Method in class org.apache.openjpa.lib.jdbc.AbstractJDBCListener
 
beforeClose(JDBCEvent) - Method in interface org.apache.openjpa.lib.jdbc.JDBCListener
 
beforeCommit(TransactionEvent) - Method in class org.apache.openjpa.event.AbstractTransactionListener
 
beforeCommit(TransactionEvent) - Method in interface org.apache.openjpa.event.EndTransactionListener
Notification that the next flush is for the transaction commit.
beforeCommit(TransactionEvent) - Method in class org.apache.openjpa.event.RemoteCommitEventManager
 
beforeCommit(JDBCEvent) - Method in class org.apache.openjpa.lib.jdbc.AbstractJDBCListener
 
beforeCommit(JDBCEvent) - Method in interface org.apache.openjpa.lib.jdbc.JDBCListener
 
beforeCompletion() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
beforeCompletion() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
beforeConfigurationConstruct(ConfigurationProvider) - Method in class org.apache.openjpa.jdbc.conf.JDBCProductDerivation
 
beforeConfigurationConstruct(ConfigurationProvider) - Method in class org.apache.openjpa.lib.conf.AbstractProductDerivation
 
beforeConfigurationConstruct(ConfigurationProvider) - Method in interface org.apache.openjpa.lib.conf.ProductDerivation
Provides the instance with a callback to mutate the initial properties of the ConfigurationProvider.
beforeConfigurationConstruct(ConfigurationProvider) - Static method in class org.apache.openjpa.lib.conf.ProductDerivations
Apply ProductDerivation.beforeConfigurationConstruct(org.apache.openjpa.lib.conf.ConfigurationProvider) callbacks to the the given instance.
beforeConfigurationLoad(Configuration) - Method in class org.apache.openjpa.lib.conf.AbstractProductDerivation
 
beforeConfigurationLoad(Configuration) - Method in interface org.apache.openjpa.lib.conf.ProductDerivation
Provides the instance with the opportunity to mutate conf before the user configuration is applied.
beforeConfigurationLoad(Configuration) - Static method in class org.apache.openjpa.lib.conf.ProductDerivations
Apply ProductDerivation.beforeConfigurationLoad(org.apache.openjpa.lib.conf.Configuration) callbacks to the the given instance.
beforeConfigurationLoad(Configuration) - Method in class org.apache.openjpa.persistence.jdbc.JDBCPersistenceProductDerivation
 
beforeConfigurationLoad(Configuration) - Method in class org.apache.openjpa.persistence.PersistenceProductDerivation
 
beforeCreateStatement(JDBCEvent) - Method in class org.apache.openjpa.lib.jdbc.AbstractJDBCListener
 
beforeCreateStatement(JDBCEvent) - Method in interface org.apache.openjpa.lib.jdbc.JDBCListener
 
beforeDelete(LifecycleEvent) - Method in class org.apache.openjpa.event.AbstractLifecycleListener
 
beforeDelete(LifecycleEvent) - Method in interface org.apache.openjpa.event.DeleteListener
Invoked before the instance transferred to a deleted state.
beforeDetach(LifecycleEvent) - Method in interface org.apache.openjpa.event.DetachListener
Invoked before the instance is detached.
beforeDirty(LifecycleEvent) - Method in class org.apache.openjpa.event.AbstractLifecycleListener
 
beforeDirty(LifecycleEvent) - Method in interface org.apache.openjpa.event.DirtyListener
Invoked before the first change is applied.
beforeDirtyFlushed(LifecycleEvent) - Method in class org.apache.openjpa.event.AbstractLifecycleListener
 
beforeDirtyFlushed(LifecycleEvent) - Method in interface org.apache.openjpa.event.DirtyListener
Invoked before the first change is applied to a flushed instance.
beforeExecuteStatement(JDBCEvent) - Method in class org.apache.openjpa.lib.jdbc.AbstractJDBCListener
 
beforeExecuteStatement(JDBCEvent) - Method in interface org.apache.openjpa.lib.jdbc.JDBCListener
 
beforeFirst() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
beforeFlush(TransactionEvent) - Method in class org.apache.openjpa.event.AbstractTransactionListener
 
beforeFlush(TransactionEvent) - Method in interface org.apache.openjpa.event.FlushTransactionListener
Notification that a transaction is about to flush all object changes.
beforePersist(LifecycleEvent) - Method in interface org.apache.openjpa.event.PersistListener
Invoked before an instance is persisted.
beforePrepareStatement(JDBCEvent) - Method in class org.apache.openjpa.lib.jdbc.AbstractJDBCListener
 
beforePrepareStatement(JDBCEvent) - Method in interface org.apache.openjpa.lib.jdbc.JDBCListener
 
beforeRefresh(boolean) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
beforeRefresh(boolean) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
beforeRefresh(boolean) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
beforeRefresh(boolean) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Prepare the instance for refresh
beforeRefresh(boolean) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
beforeReturn(JDBCEvent) - Method in class org.apache.openjpa.lib.jdbc.AbstractJDBCListener
 
beforeRollback(JDBCEvent) - Method in class org.apache.openjpa.lib.jdbc.AbstractJDBCListener
 
beforeRollback(JDBCEvent) - Method in interface org.apache.openjpa.lib.jdbc.JDBCListener
 
beforeStateChange(OpenJPAStateManager, PCState, PCState) - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
 
beforeStateChange(OpenJPAStateManager, PCState, PCState) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
beforeStateChange(OpenJPAStateManager, PCState, PCState) - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
beforeStateChange(OpenJPAStateManager, PCState, PCState) - Method in interface org.apache.openjpa.kernel.StoreManager
Notification that the given state manager is about to change its lifecycle state.
beforeStore(LifecycleEvent) - Method in class org.apache.openjpa.event.AbstractLifecycleListener
 
beforeStore(LifecycleEvent) - Method in interface org.apache.openjpa.event.StoreListener
Invoked just prior to store.
begin() - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
OpenJPA assumes that after this method is invoked, all data accesses through this store manager will be part of a single unit of work that can be rolled back.
begin() - Method in class org.apache.openjpa.datacache.DataCacheStoreManager
 
begin() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
begin() - Method in interface org.apache.openjpa.kernel.Broker
Begin a transaction.
begin() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
begin() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
begin() - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
begin() - Method in interface org.apache.openjpa.kernel.StoreManager
Begin a data store transaction.
begin() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
begin() - Method in class org.apache.openjpa.xmlstore.XMLStoreManager
 
beginOperation(boolean) - Method in interface org.apache.openjpa.kernel.Broker
Begin a logical operation.
beginOperation(boolean) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
beginOperation(boolean) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
beginOptimistic() - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
No-op implementation.
beginOptimistic() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
beginOptimistic() - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
beginOptimistic() - Method in interface org.apache.openjpa.kernel.StoreManager
Notification that an optimistic transaction has started.
beginStore() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
beginStore() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
beginStore() - Method in interface org.apache.openjpa.kernel.StoreContext
Begin a data store transaction.
beginStore() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
beginStore() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Begins a store transaction if one isn't already started.
beginTransaction() - Method in class org.apache.openjpa.kernel.AbstractLockManager
Does nothing by default.
beginTransaction() - Method in interface org.apache.openjpa.kernel.LockManager
Notification that a transaction is beginning.
beginTransaction() - Method in class org.apache.openjpa.xmlstore.XMLStore
Begin a datastore transaction.
BeginTransactionListener - Interface in org.apache.openjpa.event
Notified when transactions begin.
BIGDECIMAL - Static variable in class org.apache.openjpa.meta.JavaTypes
 
BIGINTEGER - Static variable in class org.apache.openjpa.meta.JavaTypes
 
bigintTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
BINARY_STREAM - Static variable in class org.apache.openjpa.jdbc.meta.JavaSQLTypes
 
binaryTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
bind(Value) - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
Record that the given variable is bound.
bindKeyVariable(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
bindKeyVariable(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Bind the given variable to the key set of the given map value.
bindKeyVariable(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
bindValueVariable(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
bindValueVariable(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Bind the given variable to the value set of the given map value.
bindValueVariable(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
bindVariable(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
bindVariable(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Bind the given variable to the given collection value.
bindVariable(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
bitLengthFunction - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
bitTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
BLOB - Static variable in class org.apache.openjpa.jdbc.meta.JavaSQLTypes
 
blobAsObject - Variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool.Flags
 
blobTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
BlobValueHandler - Class in org.apache.openjpa.jdbc.meta.strats
Handler for blob values.
BlobValueHandler() - Constructor for class org.apache.openjpa.jdbc.meta.strats.BlobValueHandler
 
BOOLEAN - Static variable in class org.apache.openjpa.meta.JavaTypes
 
BOOLEAN_OBJ - Static variable in class org.apache.openjpa.meta.JavaTypes
 
booleanTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
BooleanValue - Class in org.apache.openjpa.lib.conf
A boolean Value.
BooleanValue(String) - Constructor for class org.apache.openjpa.lib.conf.BooleanValue
 
Bootstrap - Class in org.apache.openjpa.kernel
Helper methods for acquiring BrokerFactory objects
Bootstrap() - Constructor for class org.apache.openjpa.kernel.Bootstrap
 
broadcast(RemoteCommitEvent) - Method in class org.apache.openjpa.event.JMSRemoteCommitProvider
 
broadcast(RemoteCommitEvent) - Method in interface org.apache.openjpa.event.RemoteCommitProvider
Notifies other remote event managers in this JVM and on other machines of changes to the cache.
broadcast(RemoteCommitEvent) - Method in class org.apache.openjpa.event.SingleJVMRemoteCommitProvider
 
broadcast(RemoteCommitEvent) - Method in class org.apache.openjpa.event.TCPRemoteCommitProvider
 
Broker - Interface in org.apache.openjpa.kernel
The broker is the primary interface into the OpenJPA runtime.
BrokerFactory - Interface in org.apache.openjpa.kernel
Factory for Broker instances.
brokerFactoryPlugin - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
BrokerFactoryValue - Class in org.apache.openjpa.conf
Value type used to represent the BrokerFactory.
BrokerFactoryValue() - Constructor for class org.apache.openjpa.conf.BrokerFactoryValue
 
BrokerImpl - Class in org.apache.openjpa.kernel
Concrete Broker.
BrokerImpl() - Constructor for class org.apache.openjpa.kernel.BrokerImpl
 
brokerPlugin - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
BYTE - Static variable in class org.apache.openjpa.meta.JavaTypes
 
BYTE_OBJ - Static variable in class org.apache.openjpa.meta.JavaTypes
 
ByteArrayValueHandler - Class in org.apache.openjpa.jdbc.meta.strats
Handler for byte array values.
ByteArrayValueHandler() - Constructor for class org.apache.openjpa.jdbc.meta.strats.ByteArrayValueHandler
 
BytecodeWriter - Interface in org.apache.openjpa.lib.util
Control how enhanced bytecode is written.
ByteId - Class in org.apache.openjpa.util
OpenJPAId subclass appropriate for byte fields.
ByteId(Class, Byte) - Constructor for class org.apache.openjpa.util.ByteId
 
ByteId(Class, String) - Constructor for class org.apache.openjpa.util.ByteId
 
ByteId(Class, byte) - Constructor for class org.apache.openjpa.util.ByteId
 
ByteId(Class, byte, boolean) - Constructor for class org.apache.openjpa.util.ByteId
 
BYTES - Static variable in class org.apache.openjpa.jdbc.meta.JavaSQLTypes
 
bytes - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary.SerializedData
 

C

CacheDictionary - Class in org.apache.openjpa.jdbc.sql
Dictionary for Intersystems Cache.
CacheDictionary() - Constructor for class org.apache.openjpa.jdbc.sql.CacheDictionary
 
CacheMap - Class in org.apache.openjpa.util
Fixed-size map that has ability to pin/unpin entries and move overflow to a backing soft map.
CacheMap() - Constructor for class org.apache.openjpa.util.CacheMap
Create a non-LRU (and therefore highly concurrent) cache map with a size of 1000.
CacheMap(boolean, int) - Constructor for class org.apache.openjpa.util.CacheMap
Create a cache map with the given properties.
CacheMap(boolean, int, int, float) - Constructor for class org.apache.openjpa.util.CacheMap
Create a cache map with the given properties.
cacheMap - Variable in class org.apache.openjpa.util.CacheMap
The map for non-expired and non-pinned references.
cacheMapOverflowRemoved(Object, Object) - Method in class org.apache.openjpa.util.CacheMap
Called from SizedMap.overflowRemoved(java.lang.Object, java.lang.Object) in the cache map.
cacheTables - Variable in class org.apache.openjpa.jdbc.sql.HSQLDictionary
Sets whether HSQL should use "CREATED CACHED TABLE" rather than "CREATE TABLE", which allows disk-based database operations.
calculateDBDictionary(JDBCConfiguration, String, String, String) - Static method in class org.apache.openjpa.jdbc.sql.DBDictionaryFactory
Attempt to create the dictionary from the given connection URL and driver name, either or both of which may be null.
calculateValue(Select, ExpContext, ExpState, Val, ExpState) - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
 
calculateValue(Select, ExpContext, ExpState, Val, ExpState) - Method in interface org.apache.openjpa.jdbc.kernel.exps.Val
Calculate and cache the SQL for this value.
calendar - Variable in class org.apache.openjpa.jdbc.sql.Calendard
 
CALENDAR - Static variable in class org.apache.openjpa.meta.JavaTypes
 
Calendard - Class in org.apache.openjpa.jdbc.sql
A calendar-modified value.
Calendard(Object, Calendar) - Constructor for class org.apache.openjpa.jdbc.sql.Calendard
 
callAbstractPCData(BCClass, String, Class, Class[]) - Method in class org.apache.openjpa.enhance.PCDataGenerator
Add method which defers to AbstractPCData.
CALLBACK - Static variable in exception org.apache.openjpa.util.UserException
 
CALLBACK_FAIL_FAST - Static variable in interface org.apache.openjpa.event.CallbackModes
Flag to stop executing callbacks on exception immediately.
CALLBACK_IGNORE - Static variable in interface org.apache.openjpa.event.CallbackModes
Flag to ignore exceptions made during callback.
CALLBACK_LOG - Static variable in interface org.apache.openjpa.event.CallbackModes
Flag to log exceptions made during callback.
CALLBACK_RETHROW - Static variable in interface org.apache.openjpa.event.CallbackModes
Flag to re-throw exceptions made during callback.
CALLBACK_ROLLBACK - Static variable in interface org.apache.openjpa.event.CallbackModes
Flag to always rollback on a callback exception.
CallbackException - Exception in org.apache.openjpa.util
Exception type thrown when an error occurs in a callback.
CallbackException(Localizer.Message) - Constructor for exception org.apache.openjpa.util.CallbackException
 
CallbackException(Throwable) - Constructor for exception org.apache.openjpa.util.CallbackException
 
CallbackModes - Interface in org.apache.openjpa.event
Callback handling constants.
cancel() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
cancel() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
cancel() - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
cancelAll() - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
Returns false.
cancelAll() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
cancelAll() - Method in interface org.apache.openjpa.kernel.Broker
Cancel all pending data store statements.
cancelAll() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
cancelAll() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
cancelAll() - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
cancelAll() - Method in interface org.apache.openjpa.kernel.StoreManager
Cancel all pending data store statements.
cancelAll() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
cancelAll() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Cancel all pending data store statements.
cancelRowUpdates() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
canConvert(Class, Class, boolean) - Static method in class org.apache.openjpa.kernel.Filters
Return whether an instance of the first class can be converted to an instance of the second.
canForeignKey() - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
The user can mark columns as explicitly not having a foreign key.
canIndex() - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
The user can mark columns as explicitly non-indexable.
canIndicateNull() - Method in class org.apache.openjpa.jdbc.meta.ValueMappingInfo
Whether user has explicitly turned null indicator column off.
canOrderColumn() - Method in class org.apache.openjpa.jdbc.meta.FieldMappingInfo
Whether we can have an ordering column.
canOuterJoin(int, ForeignKey) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Returns if the given foreign key can be eagerly loaded using other joins.
canOuterJoin(int, ForeignKey) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
canSet(ColumnIO, int, boolean) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
Return true if the given column index is settable.
canSetAny(ColumnIO, int, boolean) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
Return true if any of the given column indexes are settable.
canUnique() - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
The user can mark columns as explicitly not having a unique constraint.
capacity() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
Returns the current capacity of backing table in this map.
CASCADE_AUTO - Static variable in interface org.apache.openjpa.meta.ValueMetaData
Use automatic cascade behavior.
CASCADE_IMMEDIATE - Static variable in interface org.apache.openjpa.meta.ValueMetaData
The operation is immediately cascaded to this field.
CASCADE_NONE - Static variable in interface org.apache.openjpa.meta.ValueMetaData
The operation is not cascaded to this field.
cast(Value, Class) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
cast(Value, Class) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Cast the value to the given class.
cast(Value, Class) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
cast(EntityManagerFactory) - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
Return the OpenJPA facade to the given entity manager factory.
castFunction - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
catalogSeparator - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
CENTI - Static variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
CFMetaDataParser - Class in org.apache.openjpa.lib.meta
Custom SAX parser used by the system to quickly parse metadata files for classes.
CFMetaDataParser() - Constructor for class org.apache.openjpa.lib.meta.CFMetaDataParser
 
CFMetaDataSerializer - Class in org.apache.openjpa.lib.meta
Helps serialize metadata objects to package and class elements.
CFMetaDataSerializer() - Constructor for class org.apache.openjpa.lib.meta.CFMetaDataSerializer
 
change - Variable in class org.apache.openjpa.util.AbstractChangeTracker
Collection of changed items.
change(Object) - Method in class org.apache.openjpa.util.AbstractChangeTracker
Mark the given value as changed.
change(Object) - Method in class org.apache.openjpa.util.CollectionChangeTrackerImpl
 
change(Object) - Method in class org.apache.openjpa.util.MapChangeTrackerImpl
 
changed(Object) - Method in class org.apache.openjpa.util.AbstractChangeTracker
Notify the tracker that the given object was changed.
changed(Object, Object, Object) - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
changed(Object, Object, Object) - Method in interface org.apache.openjpa.util.MapChangeTracker
Record that the given entry was altered.
changed(Object, Object, Object) - Method in class org.apache.openjpa.util.MapChangeTrackerImpl
 
changeInvalidatesQuery(Collection) - Method in class org.apache.openjpa.datacache.QueryKey
Returns true if modifications to any of the classes in changed results in a possible invalidation of this query; otherwise returns false.
ChangeTracker - Interface in org.apache.openjpa.util
Interface for components that track changes to containers at a fine-grained level.
CHAR - Static variable in class org.apache.openjpa.meta.JavaTypes
 
CHAR_OBJ - Static variable in class org.apache.openjpa.meta.JavaTypes
 
CHAR_STREAM - Static variable in class org.apache.openjpa.jdbc.meta.JavaSQLTypes
 
characterColumnSize - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
characters(char[], int, int) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
 
CharArrayStreamValueHandler - Class in org.apache.openjpa.jdbc.meta.strats
Handler for char array values.
CharArrayStreamValueHandler() - Constructor for class org.apache.openjpa.jdbc.meta.strats.CharArrayStreamValueHandler
 
CharArrayValueHandler - Class in org.apache.openjpa.jdbc.meta.strats
Handler for char array values.
CharArrayValueHandler() - Constructor for class org.apache.openjpa.jdbc.meta.strats.CharArrayValueHandler
 
CharId - Class in org.apache.openjpa.util
OpenJPAId subclass appropriate for char fields.
CharId(Class, Character) - Constructor for class org.apache.openjpa.util.CharId
 
CharId(Class, String) - Constructor for class org.apache.openjpa.util.CharId
 
CharId(Class, char) - Constructor for class org.apache.openjpa.util.CharId
 
CharId(Class, char, boolean) - Constructor for class org.apache.openjpa.util.CharId
 
charTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
CHECK_READ - Static variable in interface org.apache.openjpa.enhance.PersistenceCapable
 
CHECK_WRITE - Static variable in interface org.apache.openjpa.enhance.PersistenceCapable
 
checkNull(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
checkVersion(OpenJPAStateManager, JDBCStore, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractVersionStrategy
 
checkVersion(OpenJPAStateManager, JDBCStore, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.ColumnVersionStrategy
 
checkVersion(OpenJPAStateManager, JDBCStore, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy
 
checkVersion(OpenJPAStateManager, JDBCStore, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.SuperclassVersionStrategy
 
checkVersion(OpenJPAStateManager, JDBCStore, boolean) - Method in class org.apache.openjpa.jdbc.meta.Version
 
checkVersion(OpenJPAStateManager, JDBCStore, boolean) - Method in interface org.apache.openjpa.jdbc.meta.VersionStrategy
Checks the version of the given state manager with the version stored in memory.
ClassAnnotationMetaDataFilter - Class in org.apache.openjpa.lib.meta
Filter that looks for classes with one of a set of annotations.
ClassAnnotationMetaDataFilter(Class) - Constructor for class org.apache.openjpa.lib.meta.ClassAnnotationMetaDataFilter
Constructor; supply annotation to match against.
ClassAnnotationMetaDataFilter(Class[]) - Constructor for class org.apache.openjpa.lib.meta.ClassAnnotationMetaDataFilter
Constructor; supply annotations to match against.
ClassArgParser - Class in org.apache.openjpa.lib.meta
Parser used to resolve arguments into java classes.
ClassArgParser() - Constructor for class org.apache.openjpa.lib.meta.ClassArgParser
 
ClassCriteria - Annotation Type in org.apache.openjpa.persistence.jdbc
Marker interface specifying to use the expected class of the relation as criteria in the join.
classForName(String, String[]) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
classForName(String, String[]) - Method in interface org.apache.openjpa.kernel.exps.Resolver
Resolve the type represented by the given class name.
classForName(String, String[]) - Method in interface org.apache.openjpa.kernel.QueryContext
Helper method to instantiate the class with the given name, taking into account the query's candidate package, automatic imports, and the given imports (if any).
classForName(String, String[]) - Method in class org.apache.openjpa.kernel.QueryImpl
 
classForName(String, boolean) - Method in class org.apache.openjpa.lib.meta.CFMetaDataParser
Helper method to create the Class for the given name, taking into account the package currently being parsed for relative class names.
classForName(String, String, boolean, ClassLoader) - Static method in class org.apache.openjpa.lib.meta.CFMetaDataParser
Load the given class name against the given package and the set of accepted standard packages.
classForName(String, ClassMetaData) - Static method in class org.apache.openjpa.meta.JavaTypes
Check the given name against the same set of standard packages used when parsing metadata.
classForName(String, ClassMetaData, ClassLoader) - Static method in class org.apache.openjpa.meta.JavaTypes
Check the given name against the same set of standard packages used when parsing metadata.
classForName(String, ValueMetaData) - Static method in class org.apache.openjpa.meta.JavaTypes
Check the given name against the same set of standard packages used when parsing metadata.
classForName(String, ValueMetaData, ClassLoader) - Static method in class org.apache.openjpa.meta.JavaTypes
Check the given name against the same set of standard packages used when parsing metadata.
classForName(String) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Instantiate the given class, taking into account the default package.
ClassMapping - Class in org.apache.openjpa.jdbc.meta
Specialization of metadata for relational databases.
ClassMapping(Class, MappingRepository) - Constructor for class org.apache.openjpa.jdbc.meta.ClassMapping
Constructor.
ClassMapping(ValueMetaData) - Constructor for class org.apache.openjpa.jdbc.meta.ClassMapping
Embedded constructor.
ClassMappingInfo - Class in org.apache.openjpa.jdbc.meta
Information about the mapping from a class to the schema, in raw form.
ClassMappingInfo() - Constructor for class org.apache.openjpa.jdbc.meta.ClassMappingInfo
 
ClassMetaData - Class in org.apache.openjpa.meta
Contains metadata about a persistent type.
ClassMetaData(Class, MetaDataRepository) - Constructor for class org.apache.openjpa.meta.ClassMetaData
Constructor.
ClassMetaData(ValueMetaData) - Constructor for class org.apache.openjpa.meta.ClassMetaData
Embedded constructor.
ClassMetaDataIterator - Class in org.apache.openjpa.lib.meta
Iterator over all metadata resources that might contain the metadata for a given class, starting with the most general.
ClassMetaDataIterator(Class, String, boolean) - Constructor for class org.apache.openjpa.lib.meta.ClassMetaDataIterator
Constructor; supply the class whose metadata to find, the suffix of metadata files, and whether to parse top-down or bottom-up.
ClassMetaDataIterator(Class, String, ClassLoader, boolean) - Constructor for class org.apache.openjpa.lib.meta.ClassMetaDataIterator
Constructor; supply the class whose metadata to find, the suffix of metadata files, and whether to parse top-down or bottom-up.
ClassNameDiscriminatorStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Stores the class name along with each database object record.
ClassNameDiscriminatorStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.ClassNameDiscriminatorStrategy
 
classpath - Variable in class org.apache.openjpa.lib.ant.AbstractTask
 
ClasspathMetaDataIterator - Class in org.apache.openjpa.lib.meta
Iterator over directories in the classpath.
ClasspathMetaDataIterator() - Constructor for class org.apache.openjpa.lib.meta.ClasspathMetaDataIterator
Default constructor; iterates over all classpath elements.
ClasspathMetaDataIterator(String[], MetaDataFilter) - Constructor for class org.apache.openjpa.lib.meta.ClasspathMetaDataIterator
Constructor; supply the classpath directories to scan and an optional resource filter.
ClassResolver - Interface in org.apache.openjpa.util
Interface to customize the loading of classes under OpenJPA.
ClassResolverImpl - Class in org.apache.openjpa.util
Default class resolver implementation.
ClassResolverImpl() - Constructor for class org.apache.openjpa.util.ClassResolverImpl
 
classResolverPlugin - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
ClassStrategy - Interface in org.apache.openjpa.jdbc.meta
Mapping from a class to a relational schema.
ClassTableJDBCSeq - Class in org.apache.openjpa.jdbc.kernel
Specialization of the TableJDBCSeq that maintains a separate sequence count per-class.
ClassTableJDBCSeq() - Constructor for class org.apache.openjpa.jdbc.kernel.ClassTableJDBCSeq
 
clear() - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
clear() - Method in class org.apache.openjpa.datacache.AbstractQueryCache
 
clear() - Method in interface org.apache.openjpa.datacache.DataCache
Remove all data from this cache.
clear() - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
clear() - Method in class org.apache.openjpa.datacache.DelegatingQueryCache
 
clear() - Method in interface org.apache.openjpa.datacache.QueryCache
Remove all data from this cache.
clear(boolean) - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
 
clear(boolean) - Method in class org.apache.openjpa.jdbc.meta.DiscriminatorMappingInfo
 
clear(boolean) - Method in class org.apache.openjpa.jdbc.meta.FieldMappingInfo
 
clear() - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Clear all mapping information.
clear(boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Clear mapping information.
clear() - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
 
clear() - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Reset the internal repository.
clear() - Method in class org.apache.openjpa.jdbc.meta.MetaDataPlusMappingFactory
 
clear(boolean) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingInfo
 
clear() - Method in interface org.apache.openjpa.jdbc.schema.SchemaSerializer
Clear the set of objects to be serialized.
clear() - Method in class org.apache.openjpa.jdbc.schema.XMLSchemaSerializer
 
clear() - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
clear() - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
clear() - Method in interface org.apache.openjpa.lib.meta.MetaDataParser
Clears the cache of parsed resource names.
clear() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
 
clear() - Method in class org.apache.openjpa.lib.rop.AbstractResultList
 
clear() - Method in class org.apache.openjpa.lib.util.CodeFormat
Clear the internal code buffer.
clear() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
Removes all mappings from this map.
clear() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashSet
 
clear() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
Removes all mappings from this HashMap.
clear() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashSet
 
clear() - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
clear() - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArraySet
Removes all of the elements from this set.
clear() - Method in class org.apache.openjpa.lib.util.FormatPreservingProperties
 
clear() - Method in class org.apache.openjpa.lib.util.MultiClassLoader
Clear the list of class loaders.
clear() - Method in class org.apache.openjpa.lib.util.ReferenceHashSet
 
clear() - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
 
clear() - Method in class org.apache.openjpa.meta.AbstractMetaDataFactory
 
clear() - Method in class org.apache.openjpa.meta.DelegatingMetaDataFactory
 
clear() - Method in interface org.apache.openjpa.meta.MetaDataFactory
Clear any internal caches.
clear() - Method in class org.apache.openjpa.meta.MetaDataRepository
Clear the cache of parsed metadata.
clear() - Method in class org.apache.openjpa.meta.MetaDataTool
Reset state.
clear() - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
clear() - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Clear caches.
clear() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
clear() - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer
 
clear() - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
 
clear() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Clear the set of metadatas to be serialized.
clear() - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
clear() - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
clear() - Method in class org.apache.openjpa.util.CacheMap
Removes pinned objects as well as unpinned ones.
clear() - Method in class org.apache.openjpa.util.ProxyArrayList
 
clear() - Method in class org.apache.openjpa.util.ProxyHashMap
 
clear() - Method in class org.apache.openjpa.util.ProxyHashSet
 
clear() - Method in class org.apache.openjpa.util.ProxyHashtable
 
clear() - Method in class org.apache.openjpa.util.ProxyLinkedList
 
clear() - Method in class org.apache.openjpa.util.ProxyProperties
 
clear() - Method in class org.apache.openjpa.util.ProxyTreeMap
 
clear() - Method in class org.apache.openjpa.util.ProxyTreeSet
 
clear() - Method in class org.apache.openjpa.util.ProxyVector
 
CLEAR_ALL - Static variable in interface org.apache.openjpa.kernel.AutoClear
Clear state when entering any transaction.
CLEAR_DATASTORE - Static variable in interface org.apache.openjpa.kernel.AutoClear
Clear state when entering a datastore transaction.
clearAllFieldCache() - Method in class org.apache.openjpa.meta.ClassMetaData
Clear cached field data.
clearBatch() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
clearBatch() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
clearBatch() - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
clearData(int) - Method in class org.apache.openjpa.datacache.DataCachePCDataImpl
 
clearData(int) - Method in class org.apache.openjpa.kernel.PCDataImpl
 
clearDecorators() - Method in class org.apache.openjpa.lib.jdbc.DecoratingDataSource
Clear all decorators.
clearDefinedFieldCache() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
clearDefinedFieldCache() - Method in class org.apache.openjpa.meta.ClassMetaData
Clear defined field data.
clearFetchGroups() - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
clearFetchGroups() - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Clears the set of fetch group names to use when loading data.
clearFetchGroups() - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
clearFetchGroups() - Method in interface org.apache.openjpa.persistence.FetchPlan
Clears the set of fetch group names to use wen loading data.
clearFetchGroups() - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
clearFieldCache() - Method in class org.apache.openjpa.meta.ClassMetaData
Clear cached field data.
clearFields() - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
clearFields() - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Clears the set of field names to use when loading data.
clearFields() - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
clearFields() - Method in interface org.apache.openjpa.persistence.FetchPlan
Clears the set of field names to use wen loading data.
clearFields() - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
clearForeignKey(ForeignKey) - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
 
clearForeignKey(ForeignKey) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
Clear a circular foreign key.
clearInternal() - Method in class org.apache.openjpa.datacache.AbstractDataCache
Clear the cache.
clearInternal() - Method in class org.apache.openjpa.datacache.AbstractQueryCache
Clear the cache.
clearInternal() - Method in class org.apache.openjpa.datacache.ConcurrentDataCache
 
clearInternal() - Method in class org.apache.openjpa.datacache.ConcurrentQueryCache
 
clearInverseRelations(OpenJPAStateManager, FieldMetaData, FieldMetaData[], Object) - Method in class org.apache.openjpa.kernel.InverseManager
Remove all relations between the initial value of fmd for the instance managed by sm and its inverses.
clearInverseRelations(OpenJPAStateManager, Object, FieldMetaData, FieldMetaData[]) - Method in class org.apache.openjpa.kernel.InverseManager
Clear all inverse the relations from val to the instance managed by sm.
clearJoins() - Method in class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
 
clearJoins() - Method in interface org.apache.openjpa.jdbc.kernel.JDBCFetchConfiguration
Clears the set of field names to join when loading data.
clearJoins() - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
ClearListener - Interface in org.apache.openjpa.event
Listener for when persistent state is cleared from an instance.
clearMapping() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Clear mapping information, including strategy.
clearMapping() - Method in class org.apache.openjpa.jdbc.meta.Discriminator
Clear mapping information, including strategy.
clearMapping() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Clear mapping information, including strategy.
clearMapping() - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
Clear mapping information, including strategy.
clearMapping() - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
clearMapping() - Method in class org.apache.openjpa.jdbc.meta.Version
Clear mapping information, including strategy.
clearMapping(ClassMetaData) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Clear mapping information from the given metadata.
clearOrdering() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
clearOrdering() - Method in interface org.apache.openjpa.jdbc.sql.Select
Clear odering conditions.
clearOrdering() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
clearParameters() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
clearParameters() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
clearParameters() - Method in class org.apache.openjpa.lib.util.ParameterTemplate
Clear the recorded parameter values.
clearPlaceholderSelects() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
Clear selected placeholders, and return removed select indexes.
clearRelationId(Column) - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
 
clearRelationId(Column) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
Clear a circular relation id.
clearSelects() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
clearSelects() - Method in interface org.apache.openjpa.jdbc.sql.Select
Clear the existing column selects.
clearSelects() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
clearSubclassCache() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
clearSubclassCache() - Method in class org.apache.openjpa.meta.ClassMetaData
Clear cached subclass data.
clearWarnings() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
clearWarnings() - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
clearWarnings() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
clearWarnings() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
clearWarnings() - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
CLOB - Static variable in class org.apache.openjpa.jdbc.meta.JavaSQLTypes
 
clobTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
ClobValueHandler - Class in org.apache.openjpa.jdbc.meta.strats
Handler for clob values.
ClobValueHandler() - Constructor for class org.apache.openjpa.jdbc.meta.strats.ClobValueHandler
 
clone() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Return a new tool with the same settings as this one.
clone() - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
 
clone() - Method in class org.apache.openjpa.jdbc.sql.Join
 
clone() - Method in class org.apache.openjpa.jdbc.sql.RowImpl
Performs a proper deep clone.
clone() - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Perform a shallow clone of this SQL Buffer.
clone() - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
clone() - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Clone this instance.
clone() - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
Clone this instance.
clone() - Method in interface org.apache.openjpa.lib.conf.Configuration
Return a copy of this configuration.
clone() - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
Uses ConfigurationImpl.toProperties(boolean) and ConfigurationImpl.fromProperties(java.util.Map) to clone configuration.
clone() - Method in class org.apache.openjpa.lib.conf.Value
 
clone() - Method in class org.apache.openjpa.lib.util.CodeFormat
Make a copy of this code format object with all the same formatting settings.
clone() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
Returns a shallow copy of this ConcurrentHashMap instance: the keys and values themselves are not cloned.
clone() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap.Entry
 
clone() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
Returns a shallow copy of this HashMap.
clone() - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
clone() - Method in class org.apache.openjpa.lib.util.FormatPreservingProperties
 
clone(Object[]) - Static method in class org.apache.openjpa.util.ArrayStateImage
Clone a state array.
clone() - Method in class org.apache.openjpa.xmlstore.ObjectData
Clone this data.
close() - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
 
close() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
close() - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
close(boolean) - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
close() - Method in class org.apache.openjpa.datacache.AbstractQueryCache
 
close(boolean) - Method in class org.apache.openjpa.datacache.AbstractQueryCache
 
close() - Method in interface org.apache.openjpa.datacache.DataCache
Free the resources used by this cache.
close() - Method in interface org.apache.openjpa.datacache.DataCacheManager
Close all caches.
close() - Method in class org.apache.openjpa.datacache.DataCacheManagerImpl
 
close() - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
close() - Method in class org.apache.openjpa.datacache.DelegatingQueryCache
 
close() - Method in interface org.apache.openjpa.datacache.QueryCache
Free the resources used by this cache.
close() - Method in class org.apache.openjpa.event.JMSRemoteCommitProvider
 
close() - Method in class org.apache.openjpa.event.RemoteCommitEventManager
Close this manager and all registered listeners.
close() - Method in interface org.apache.openjpa.event.RemoteCommitListener
Free the resources used by this listener.
close() - Method in interface org.apache.openjpa.event.RemoteCommitProvider
Free the resources used by this provider.
close() - Method in class org.apache.openjpa.event.SingleJVMRemoteCommitProvider
 
close() - Method in class org.apache.openjpa.event.TCPRemoteCommitProvider
 
close() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
Free the data sources.
close() - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSeq
No-op.
close() - Method in class org.apache.openjpa.jdbc.kernel.GenericResultObjectProvider
 
close() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
close() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager.RefCountConnection
 
close() - Method in class org.apache.openjpa.jdbc.kernel.SelectResultObjectProvider
 
close() - Method in class org.apache.openjpa.jdbc.meta.PropertiesReverseCustomizer
 
close() - Method in interface org.apache.openjpa.jdbc.meta.ReverseCustomizer
Invoked when the customizer is no longer needed.
close() - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
Closes all eager results.
close() - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
close() - Method in interface org.apache.openjpa.jdbc.sql.Result
Free the resources used by this result; do not close the SQL connection.
close() - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
close() - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
 
close() - Method in class org.apache.openjpa.kernel.AbstractLockManager
Does nothing by default.
close() - Method in class org.apache.openjpa.kernel.AbstractPCResultObjectProvider
Override if desired.
close() - Method in interface org.apache.openjpa.kernel.Broker
Close the broker.
close() - Method in interface org.apache.openjpa.kernel.BrokerFactory
Close the factory.
close() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
close() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
close() - Method in class org.apache.openjpa.kernel.DelegatingBrokerFactory
 
close() - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
close() - Method in class org.apache.openjpa.kernel.DelegatingSeq
 
close() - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
close() - Method in interface org.apache.openjpa.kernel.LockManager
Free any resources.
close() - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
close(boolean) - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
close() - Method in interface org.apache.openjpa.kernel.Seq
Free resources used by this sequence.
close() - Method in interface org.apache.openjpa.kernel.StoreManager
Free any resources this store manager is using.
close() - Method in class org.apache.openjpa.kernel.TimeSeededSeq
 
close() - Method in class org.apache.openjpa.kernel.UUIDHexSeq
 
close() - Method in class org.apache.openjpa.kernel.UUIDStringSeq
 
close() - Method in interface org.apache.openjpa.lib.conf.Configuration
Free the resources used by this object.
close() - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
Closes all closeable values and plugins.
close() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
close() - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
close() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDataSource
 
close() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
close() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
close() - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
close() - Method in class org.apache.openjpa.lib.meta.ClassMetaDataIterator
 
close() - Method in class org.apache.openjpa.lib.meta.FileMetaDataIterator
 
close() - Method in interface org.apache.openjpa.lib.meta.MetaDataIterator
Close the resources used by this iterator.
close() - Method in class org.apache.openjpa.lib.meta.MetaDataIteratorChain
 
close() - Method in class org.apache.openjpa.lib.meta.ResourceMetaDataIterator
 
close() - Method in class org.apache.openjpa.lib.meta.URLMetaDataIterator
 
close() - Method in class org.apache.openjpa.lib.meta.ZipFileMetaDataIterator
 
close() - Method in class org.apache.openjpa.lib.meta.ZipStreamMetaDataIterator
 
close() - Method in class org.apache.openjpa.lib.rop.LazyForwardResultList
 
close() - Method in class org.apache.openjpa.lib.rop.ListResultList
 
close() - Method in class org.apache.openjpa.lib.rop.ListResultObjectProvider
 
close() - Method in class org.apache.openjpa.lib.rop.MergedResultObjectProvider
 
close() - Method in class org.apache.openjpa.lib.rop.RandomAccessResultList
 
close() - Method in class org.apache.openjpa.lib.rop.RangeResultObjectProvider
 
close() - Method in interface org.apache.openjpa.lib.rop.ResultList
Close the list.
close() - Method in interface org.apache.openjpa.lib.rop.ResultObjectProvider
Free the resources associated with this provider.
close() - Method in class org.apache.openjpa.lib.rop.ResultObjectProviderIterator
Close the underlying result object provider.
close() - Method in class org.apache.openjpa.lib.rop.SimpleResultList
 
close() - Method in class org.apache.openjpa.lib.rop.WindowResultList
 
close() - Method in interface org.apache.openjpa.lib.util.Closeable
 
close() - Method in class org.apache.openjpa.lib.xml.DocTypeReader
 
close() - Method in class org.apache.openjpa.meta.MetaDataRepository
Free the resources used by this repository.
close() - Method in class org.apache.openjpa.meta.SequenceMetaData
Close user sequence instance.
close() - Method in class org.apache.openjpa.persistence.EntityManagerFactoryImpl
 
close() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
close(Object) - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
Close the given resource.
close(Object) - Static method in class org.apache.openjpa.util.ImplHelper
Close the given resource.
Closeable - Interface in org.apache.openjpa.lib.util
Generic interface for components that can be closed so that helpers can treate them in a generic way.
closeAll() - Method in class org.apache.openjpa.kernel.DelegatingExtent
 
closeAll() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
closeAll() - Method in interface org.apache.openjpa.kernel.Extent
Close all open iterators.
closeAll() - Method in class org.apache.openjpa.kernel.ExtentImpl
 
closeAll() - Method in interface org.apache.openjpa.kernel.Query
Close all open query results.
closeAll() - Method in class org.apache.openjpa.kernel.QueryImpl
 
closeAll() - Method in interface org.apache.openjpa.persistence.Extent
Close all open iterators that are consuming database resources.
closeAll() - Method in class org.apache.openjpa.persistence.ExtentImpl
 
closeAll() - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Close all open query results.
closeAll() - Method in class org.apache.openjpa.persistence.QueryImpl
 
closeBrace(int) - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
closeClassBrace(CodeFormat) - Method in class org.apache.openjpa.enhance.CodeGenerator
Append the closing code-level brace to the code; this can be overridden to add code to the bottom of the class.
closeConnection(Connection) - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSeq
Close the current connection.
closeDataSource(DataSource) - Static method in class org.apache.openjpa.jdbc.schema.DataSourceFactory
Close the given data source.
closeDataSource(DataSource) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Closes the specified DataSource and releases any resources associated with it.
closeDataSource(DataSource) - Method in class org.apache.openjpa.jdbc.sql.DerbyDictionary
 
closeEagerMap(Map) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
Close all results in eager map.
closeParen() - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
closePoolSQL - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
closeResources() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
closeResources() - Method in interface org.apache.openjpa.kernel.Query
Close query results that are consuming resources.
closeResources() - Method in class org.apache.openjpa.kernel.QueryImpl
 
cls - Variable in class org.apache.openjpa.jdbc.meta.strats.AbstractClassStrategy
The owning class mapping.
CodeFormat - Class in org.apache.openjpa.lib.util
Encapsulates some common Java source code formatting options.
CodeFormat() - Constructor for class org.apache.openjpa.lib.util.CodeFormat
 
CodeGenerator - Class in org.apache.openjpa.enhance
Generates Java class code from metadata.
CodeGenerator(OpenJPAConfiguration, Class) - Constructor for class org.apache.openjpa.enhance.CodeGenerator
Constructor.
CodeGenerator(ClassMetaData) - Constructor for class org.apache.openjpa.enhance.CodeGenerator
Constructor.
COLLECTION - Static variable in class org.apache.openjpa.meta.JavaTypes
 
CollectionChangeTracker - Interface in org.apache.openjpa.util
Change tracker that can be used for collections.
CollectionChangeTrackerImpl - Class in org.apache.openjpa.util
Default CollectionChangeTracker.
CollectionChangeTrackerImpl(Collection, boolean, boolean, OpenJPAConfiguration) - Constructor for class org.apache.openjpa.util.CollectionChangeTrackerImpl
Constructor.
collectionToArray(Collection) - Static method in class org.apache.openjpa.lib.util.concurrent.Utils
 
collectionToArray(Collection, Object[]) - Static method in class org.apache.openjpa.lib.util.concurrent.Utils
 
Column - Class in org.apache.openjpa.jdbc.schema
Represents a database column.
Column() - Constructor for class org.apache.openjpa.jdbc.schema.Column
Default constructor.
Column(String, Table) - Constructor for class org.apache.openjpa.jdbc.schema.Column
Constructor.
ColumnIO - Class in org.apache.openjpa.jdbc.schema
Metadata about column I/O in a specific context.
ColumnIO() - Constructor for class org.apache.openjpa.jdbc.schema.ColumnIO
 
Columns - Annotation Type in org.apache.openjpa.persistence.jdbc
Allows the specification of multiple columns for complex mappings.
columnsMatch(Column[], Column[]) - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Return true if the given local and foreign columns match those on this key.
columnsMatch(Column[]) - Method in class org.apache.openjpa.jdbc.schema.LocalConstraint
Return true if the given columns match the columns of this constraint.
ColumnVersionStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Uses a single column and corresponding version object.
ColumnVersionStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.ColumnVersionStrategy
 
comment(char[], int, int) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
 
Commentable - Interface in org.apache.openjpa.lib.xml
Implementations of this interface can be adorned with comments.
commit() - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
This is a no-op implementation.
commit(Collection, Collection, Collection, Collection) - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
commit(Collection, Collection, Collection, Collection) - Method in interface org.apache.openjpa.datacache.DataCache
Perform a batch update of the cache.
commit() - Method in class org.apache.openjpa.datacache.DataCacheStoreManager
 
commit(Collection, Collection, Collection, Collection) - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
commit() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
commit() - Method in interface org.apache.openjpa.kernel.Broker
Commit the current transaction.
commit() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
commit() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
commit() - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
commit() - Method in interface org.apache.openjpa.kernel.StoreManager
Commit the current data store transaction.
commit() - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
commit() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
commit() - Method in class org.apache.openjpa.xmlstore.XMLStoreManager
 
commitAndResume() - Method in interface org.apache.openjpa.kernel.Broker
Issue a commit and then start a new transaction.
commitAndResume() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
commitAndResume() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
commitAndResume() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
commitAndResume() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Issue a commit and then start a new transaction.
CommonsLogFactory - Class in org.apache.openjpa.lib.log
LogFactory implementation that delegates to the commons logging framework.
CommonsLogFactory() - Constructor for class org.apache.openjpa.lib.log.CommonsLogFactory
 
CommonsLogFactory.LogAdapter - Class in org.apache.openjpa.lib.log
Adapts a commons logging log to the Log interface.
COMPACT - Static variable in interface org.apache.openjpa.lib.meta.MetaDataSerializer
 
compare(Object, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.ColumnVersionStrategy
Compare the two versions.
compare(Object, Object) - Method in class org.apache.openjpa.meta.InheritanceComparator
 
compare(Object, Object) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer.SerializationComparator
 
compareTo(Object) - Method in class org.apache.openjpa.jdbc.schema.Schema
 
compareTo(Object) - Method in class org.apache.openjpa.jdbc.schema.Sequence
 
compareTo(Object) - Method in class org.apache.openjpa.jdbc.schema.Table
 
compareTo(Object) - Method in class org.apache.openjpa.meta.ClassMetaData
 
compareTo(Object) - Method in class org.apache.openjpa.meta.FieldMetaData
 
compareTo(Object) - Method in class org.apache.openjpa.meta.NonPersistentMetaData
 
compareTo(Object) - Method in class org.apache.openjpa.util.OpenJPAId
 
compareUnknown(Object, Object) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer.MappingSerializationComparator
 
compareUnknown(Object, Object) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer.SerializationComparator
Compare two unrecognized elements of the same type.
compareVersion(OpenJPAStateManager, Object, Object) - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
Casts v1 and v2 to Comparable, and invokes v1.compareTo (v2).
compareVersion(OpenJPAStateManager, Object, Object) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
compareVersion(Object, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractVersionStrategy
 
compareVersion(Object, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.ColumnVersionStrategy
 
compareVersion(Object, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy
 
compareVersion(Object, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.SuperclassVersionStrategy
 
compareVersion(Object, Object) - Method in class org.apache.openjpa.jdbc.meta.Version
 
compareVersion(Object, Object) - Method in interface org.apache.openjpa.jdbc.meta.VersionStrategy
 
compareVersion(OpenJPAStateManager, Object, Object) - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
compareVersion(OpenJPAStateManager, Object, Object) - Method in interface org.apache.openjpa.kernel.StoreManager
Compare the two version objects.
comparison(SQLBuffer, String, FilterValue, FilterValue) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Append a comparison.
Compatibility - Class in org.apache.openjpa.conf
Struct encompassing backwards-compatibility options.
Compatibility() - Constructor for class org.apache.openjpa.conf.Compatibility
 
compatibilityPlugin - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
compile() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
compile() - Method in interface org.apache.openjpa.kernel.Query
Compile the query.
compile() - Method in class org.apache.openjpa.kernel.QueryImpl
 
compile() - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Compile the query.
compile() - Method in class org.apache.openjpa.persistence.QueryImpl
 
computeFields() - Method in class org.apache.openjpa.util.ProxyGregorianCalendar
 
concat(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
concat(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return a value representing the concatenation of the given target with the given args.
concat(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
concatenateDelimiter - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
concatenateFunction - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
ConcurrentDataCache - Class in org.apache.openjpa.datacache
A DataCache implementation that is optimized for concurrent access.
ConcurrentDataCache() - Constructor for class org.apache.openjpa.datacache.ConcurrentDataCache
 
ConcurrentHashMap - Class in org.apache.openjpa.lib.util.concurrent
This class implements a HashMap which has limited synchronization.
ConcurrentHashMap(int, float) - Constructor for class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
Constructs an empty ConcurrentHashMap with the specified initial capacity and load factor.
ConcurrentHashMap(int) - Constructor for class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
Constructs an empty ConcurrentHashMap with the specified initial capacity and the default load factor(0.75).
ConcurrentHashMap() - Constructor for class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
Constructs an empty ConcurrentHashMap with the default initial capacity(16) and the default load factor(0.75).
ConcurrentHashMap(Map) - Constructor for class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
Constructs a new ConcurrentHashMap with the same mappings as the specified Map.
ConcurrentHashMap.Entry - Class in org.apache.openjpa.lib.util.concurrent
 
ConcurrentHashMap.Entry(int, Object, Object, ConcurrentHashMap.Entry) - Constructor for class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap.Entry
Create new entry.
ConcurrentHashSet - Class in org.apache.openjpa.lib.util.concurrent
A concurrent set.
ConcurrentHashSet() - Constructor for class org.apache.openjpa.lib.util.concurrent.ConcurrentHashSet
Construct a set with the given reference type.
ConcurrentLinkedQueue - Class in org.apache.openjpa.lib.util.concurrent
An unbounded thread-safe queue based on linked nodes.
ConcurrentLinkedQueue() - Constructor for class org.apache.openjpa.lib.util.concurrent.ConcurrentLinkedQueue
 
ConcurrentLinkedQueue(Collection) - Constructor for class org.apache.openjpa.lib.util.concurrent.ConcurrentLinkedQueue
Creates a ConcurrentLinkedQueue initially containing the elements of the given collection, added in traversal order of the collection's iterator.
ConcurrentMap - Interface in org.apache.openjpa.lib.util.concurrent
A highly concurrent map.
ConcurrentQueryCache - Class in org.apache.openjpa.datacache
A QueryCache implementation that is optimized for concurrent access.
ConcurrentQueryCache() - Constructor for class org.apache.openjpa.datacache.ConcurrentQueryCache
 
ConcurrentReferenceHashMap - Class in org.apache.openjpa.lib.util.concurrent
This class implements a HashMap which has limited synchronization and reference keys or values(but not both).
ConcurrentReferenceHashMap(int, int, int, float) - Constructor for class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
Constructs a new, empty HashMap with the specified initial capacity and the specified load factor.
ConcurrentReferenceHashMap(int, int, int) - Constructor for class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
Constructs a new, empty HashMap with the specified initial capacity and default load factor.
ConcurrentReferenceHashMap(int, int) - Constructor for class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
Constructs a new, empty HashMap with a default capacity and load factor.
ConcurrentReferenceHashMap(int, int, Map) - Constructor for class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
Constructs a new HashMap with the same mappings as the given Map.
ConcurrentReferenceHashSet - Class in org.apache.openjpa.lib.util.concurrent
A concurrent set whose values may be stored as weak or soft references.
ConcurrentReferenceHashSet(int) - Constructor for class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashSet
Construct a set with the given reference type.
Condition - Interface in org.apache.openjpa.lib.util.concurrent
Condition factors out the Object monitor methods(wait, notify and notifyAll) into distinct objects to give the effect of having multiple wait-sets per object, by combining them with the use of arbitrary Lock implementations.
conf - Variable in class org.apache.openjpa.datacache.AbstractDataCache
The configuration set by the system.
conf - Variable in class org.apache.openjpa.datacache.AbstractQueryCache
The configuration set by the system.
conf - Variable in class org.apache.openjpa.jdbc.kernel.AbstractUpdateManager
 
conf - Variable in class org.apache.openjpa.jdbc.meta.StrategyInstaller
 
conf - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
conf - Variable in class org.apache.openjpa.util.ProxyManagerImpl
 
Configurable - Interface in org.apache.openjpa.lib.conf
This interface provides a mechanism for notifying interested objects when configuration events occur.
Configuration - Interface in org.apache.openjpa.lib.conf
Interface for generic configuration objects.
ConfigurationImpl - Class in org.apache.openjpa.lib.conf
Default implementation of the Configuration interface.
ConfigurationImpl() - Constructor for class org.apache.openjpa.lib.conf.ConfigurationImpl
Default constructor.
ConfigurationImpl(boolean) - Constructor for class org.apache.openjpa.lib.conf.ConfigurationImpl
Constructor.
ConfigurationProvider - Interface in org.apache.openjpa.lib.conf
Implementations of this interface can populate Configurations in some environment-specific way.
Configurations - Class in org.apache.openjpa.lib.conf
Utility methods dealing with configuration.
Configurations() - Constructor for class org.apache.openjpa.lib.conf.Configurations
 
configureBroker(BrokerImpl) - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
Configures the given broker with the current factory option settings.
configureEventManager(RemoteCommitEventManager) - Method in class org.apache.openjpa.conf.RemoteCommitProviderValue
Configure the remote event manager.
configureInstance(Object, Configuration, String) - Static method in class org.apache.openjpa.lib.conf.Configurations
Configures the given object with the given properties by matching the properties string to the object's setter methods.
configureInstance(Object, Configuration, String, String) - Static method in class org.apache.openjpa.lib.conf.Configurations
Configures the given object with the given properties by matching the properties string to the object's setter methods.
configureInstance(Object, Configuration, Properties) - Static method in class org.apache.openjpa.lib.conf.Configurations
Configures the given object with the given properties by matching the properties string to the object's setter methods.
configureInstance(Object, Configuration, Properties, String) - Static method in class org.apache.openjpa.lib.conf.Configurations
Configures the given object with the given properties by matching the properties string to the object's setter methods.
ConfiguringConnectionDecorator - Class in org.apache.openjpa.lib.jdbc
Connection decorator that can configure some properties of the underlying connection.
ConfiguringConnectionDecorator() - Constructor for class org.apache.openjpa.lib.jdbc.ConfiguringConnectionDecorator
 
CONN_RETAIN_ALWAYS - Static variable in interface org.apache.openjpa.kernel.ConnectionRetainModes
Constant indicating that each broker will retain a single connection that it will use for its lifespan.
CONN_RETAIN_DEMAND - Static variable in interface org.apache.openjpa.kernel.ConnectionRetainModes
Constant indicating that connections will be obtained as needed.
CONN_RETAIN_TRANS - Static variable in interface org.apache.openjpa.kernel.ConnectionRetainModes
Constant indicating that connections will be retained for the life of each transaction.
connected - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
connectedConfiguration(Connection) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
This method is called when the dictionary first sees any connection.
connectedConfiguration(Connection) - Method in class org.apache.openjpa.jdbc.sql.InformixDictionary
 
connectedConfiguration(Connection) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
connectedConfiguration(Connection) - Method in class org.apache.openjpa.jdbc.sql.SQLServerDictionary
 
connectInternal() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
Connect to the database.
connection2DriverName - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
connection2Password - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
connection2Properties - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
connection2URL - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
connection2UserName - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
ConnectionDecorator - Interface in org.apache.openjpa.lib.jdbc
A connection decorator can wrap Connections before they are returned to the user to add functionality.
connectionDecoratorPlugins - Variable in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
connectionDriverName - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
connectionFactory - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
connectionFactory2 - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
connectionFactory2Name - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
connectionFactory2Properties - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
connectionFactoryMode - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
connectionFactoryName - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
connectionFactoryProperties - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
ConnectionInfo - Class in org.apache.openjpa.jdbc.kernel
Struct to hold data about the current connection state.
ConnectionInfo() - Constructor for class org.apache.openjpa.jdbc.kernel.ConnectionInfo
 
connectionPassword - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
connectionProperties - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
connectionRetainMode - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
ConnectionRetainModes - Interface in org.apache.openjpa.kernel
Connection retain mode constants.
connectionURL - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
connectionUserName - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
CONS_NAME_AFTER - Static variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
CONS_NAME_BEFORE - Static variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
CONS_NAME_MID - Static variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
Constant - Interface in org.apache.openjpa.kernel.exps
Interface for any query constant value.
Constraint - Class in org.apache.openjpa.jdbc.schema
A table constraint.
constraintNameMode - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
ContainerFieldStrategy - Class in org.apache.openjpa.jdbc.meta.strats
An abstract container mapping that handles traversing the join to examine the size of the relation.
ContainerFieldStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.ContainerFieldStrategy
 
ContainerTable - Annotation Type in org.apache.openjpa.persistence.jdbc
Table for array, collection, or map elements.
contains(Object) - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
contains(Object) - Method in interface org.apache.openjpa.datacache.DataCache
Returns true if this cache contains data corresponding to oid; otherwise returns false.
contains(Object) - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
contains(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
contains(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
contains(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
contains(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
contains(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
contains(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return true if the given id or column is available in the result.
contains(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return true if the given column is available in the result.
contains(Object) - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
contains(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return an expression representing the given condition.
contains(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
contains(Object) - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
contains(Object) - Method in class org.apache.openjpa.lib.rop.AbstractNonSequentialResultList
 
contains(Object) - Method in class org.apache.openjpa.lib.rop.AbstractSequentialResultList
 
contains(Object) - Method in class org.apache.openjpa.lib.rop.ListResultList
 
contains(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashSet
 
contains(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentLinkedQueue
Returns true if this queue contains the specified element.
contains(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashSet
 
contains(Object) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
contains(Object) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArraySet
Returns true if this set contains the specified element.
contains(Object) - Method in class org.apache.openjpa.lib.util.ReferenceHashSet
 
contains(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
contains(Class, Object) - Method in interface org.apache.openjpa.persistence.StoreCache
Whether the cache contains data for the given oid.
contains(Class, Object) - Method in class org.apache.openjpa.persistence.StoreCacheImpl
 
contains(Object) - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
CONTAINS_TYPE_ELEMENT - Static variable in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
 
CONTAINS_TYPE_KEY - Static variable in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
 
CONTAINS_TYPE_VALUE - Static variable in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
 
containsAll(Collection) - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
containsAll(Collection) - Method in interface org.apache.openjpa.datacache.DataCache
Returns the indexes of the oids in this cache.
containsAll(Collection) - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
containsAll(Object[]) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
containsAll(Column[], Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
containsAll(Object[]) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
containsAll(Column[], Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
containsAll(Object[]) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return true if all the given ids or columns are available in the result.
containsAll(Column[], Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return true if all the given columns are available in the result.
containsAll(Collection) - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
containsAll(Collection) - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
containsAll(Collection) - Method in class org.apache.openjpa.lib.rop.AbstractNonSequentialResultList
 
containsAll(Collection) - Method in class org.apache.openjpa.lib.rop.AbstractSequentialResultList
 
containsAll(Collection) - Method in class org.apache.openjpa.lib.rop.ListResultList
 
containsAll(Collection) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashSet
 
containsAll(Collection) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashSet
 
containsAll(Collection) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
containsAll(Collection) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArraySet
Returns true if this set contains all of the elements of the specified collection.
containsAll(Collection) - Method in class org.apache.openjpa.lib.util.ReferenceHashSet
 
containsAll(Object...) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
containsAll(Collection) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
containsAll(Object...) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether the given objects are managed.
containsAll(Collection) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether the given objects are managed.
containsAll(Class, Object...) - Method in interface org.apache.openjpa.persistence.StoreCache
Whether the cache contains data for the given oids.
containsAll(Class, Collection) - Method in interface org.apache.openjpa.persistence.StoreCache
Whether the cache contains data for the given oids.
containsAll(Class, Object...) - Method in class org.apache.openjpa.persistence.StoreCacheImpl
 
containsAll(Class, Collection) - Method in class org.apache.openjpa.persistence.StoreCacheImpl
 
containsAll(Collection) - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
containsAllInternal(Object[], Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
Return whether this result contains data for all the given ids or columns.
containsAllInternal(Object[], Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
containsClassLoader(ClassLoader) - Method in class org.apache.openjpa.lib.util.MultiClassLoader
Returns true if the list contains the given class loader or marker.
containsColumn(Column) - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Return true if the fk includes the given local column.
containsColumn(Column) - Method in class org.apache.openjpa.jdbc.schema.LocalConstraint
Return true if the pk includes the given column.
containsConstantColumn(Column) - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Return true if the fk includes the given local column.
containsConstantPrimaryKeyColumn(Column) - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Return true if the fk includes the given primary key column.
containsInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
Return whether this result contains data for the given id or column.
containsInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
containsInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
containsKey(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
containsKey(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return an expression representing the given condition.
containsKey(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
containsKey(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
Returns true if this map contains a mapping for the specified key.
containsKey(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
Returns true if this HashMap contains a mapping for the specified key.
containsKey(Object) - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
containsKey(Object) - Method in class org.apache.openjpa.util.CacheMap
 
containsPrimaryKeyColumn(Column) - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Return true if the fk includes the given primary key column.
containsProperty(String, Map) - Static method in class org.apache.openjpa.lib.conf.Configurations
Test whether the map contains the given key, prefixed with any possible configuration prefix.
containsValue(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
containsValue(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return an expression representing the given condition.
containsValue(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
containsValue(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
Returns true if this map maps one or more keys to the specified value.
containsValue(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
Returns true if this HashMap maps one or more keys to the specified value.
containsValue(Object) - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
containsValue(Object) - Method in class org.apache.openjpa.util.CacheMap
 
convert(Object, Class) - Static method in class org.apache.openjpa.kernel.Filters
Convert the given value to the given type.
convert(long, TimeUnit) - Method in class org.apache.openjpa.lib.util.concurrent.TimeUnit
Convert the given time duration in the given unit to this unit.
convert(Object, int) - Static method in class org.apache.openjpa.meta.JavaTypes
Convert the given object to the given type if possible.
convertSchemaCase(String) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified schema name to a name that the database will be able to understand.
copy(FetchConfiguration) - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
copy(ClassMetaData) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
copy(MappingInfo) - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
 
copy(MappingInfo) - Method in class org.apache.openjpa.jdbc.meta.DiscriminatorMappingInfo
 
copy(FieldMetaData) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
copy(MappingInfo) - Method in class org.apache.openjpa.jdbc.meta.FieldMappingInfo
 
copy(MappingInfo) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Copy missing info from the instance to this one.
copy(MappingInfo) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingInfo
 
copy(Column) - Method in class org.apache.openjpa.jdbc.schema.Column
Copy information from the given column to this one.
copy(SchemaGroup) - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Copy cloneable state from the given instance.
copy(FetchConfiguration) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
copy(FetchConfiguration) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Copy the state from the given fetch configuration to this one.
copy(FetchConfiguration) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
copy(File, File) - Static method in class org.apache.openjpa.lib.util.Files
Copy a file.
copy(ClassMetaData) - Method in class org.apache.openjpa.meta.ClassMetaData
Copy the metadata from the given instance to this one.
copy(Extensions) - Method in class org.apache.openjpa.meta.Extensions
Copy the extensions not present in this instance but present in the given instance.
copy(FieldMetaData) - Method in class org.apache.openjpa.meta.FieldMetaData
Copy state from the given field to this one.
copy(ValueMetaData) - Method in class org.apache.openjpa.meta.FieldMetaData
 
copy(ValueMetaData) - Method in interface org.apache.openjpa.meta.ValueMetaData
Copy state from the given value to this one.
copy(ValueMetaData) - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
copy(Object) - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
copy(Object) - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
copy(Object, ClassMetaData) - Static method in class org.apache.openjpa.util.ApplicationIds
Copy the given oid value.
copy(Object) - Method in interface org.apache.openjpa.util.Proxy
Return an unproxied copy of the given instance.
copy(Object) - Method in class org.apache.openjpa.util.ProxyArrayList
 
copy(Object) - Method in class org.apache.openjpa.util.ProxyGregorianCalendar
 
copy(Object) - Method in class org.apache.openjpa.util.ProxyHashMap
 
copy(Object) - Method in class org.apache.openjpa.util.ProxyHashSet
 
copy(Object) - Method in class org.apache.openjpa.util.ProxyHashtable
 
copy(Object) - Method in class org.apache.openjpa.util.ProxyLinkedList
 
copy(Object) - Method in class org.apache.openjpa.util.ProxyProperties
 
copy(Object) - Method in class org.apache.openjpa.util.ProxySQLDate
 
copy(Object) - Method in class org.apache.openjpa.util.ProxyTime
 
copy(Object) - Method in class org.apache.openjpa.util.ProxyTimestamp
 
copy(Object) - Method in class org.apache.openjpa.util.ProxyTreeMap
 
copy(Object) - Method in class org.apache.openjpa.util.ProxyTreeSet
 
copy(Object) - Method in class org.apache.openjpa.util.ProxyUtilDate
 
copy(Object) - Method in class org.apache.openjpa.util.ProxyVector
 
copyArray(Object) - Method in interface org.apache.openjpa.util.ProxyManager
Return a new array of the same component type as the given array and containing the same elements.
copyArray(Object) - Method in class org.apache.openjpa.util.ProxyManagerImpl
 
copyCalendar(Calendar) - Method in interface org.apache.openjpa.util.ProxyManager
Return a copy of the given Calendar with the same information.
copyCalendar(Calendar) - Method in class org.apache.openjpa.util.ProxyManagerImpl
 
copyCollection(Collection) - Method in interface org.apache.openjpa.util.ProxyManager
Return a new collection of the same type as the given one with a copy of all contained elements.
copyCollection(Collection) - Method in class org.apache.openjpa.util.ProxyManagerImpl
 
copyCustom(Object) - Method in interface org.apache.openjpa.util.ProxyManager
Return a copy of the given object with the same information.
copyCustom(Object) - Method in class org.apache.openjpa.util.ProxyManagerImpl
 
copyDataStoreId(Object, ClassMetaData) - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
 
copyDataStoreId(Object, ClassMetaData) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
copyDataStoreId(Object, ClassMetaData) - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
copyDataStoreId(Object, ClassMetaData) - Method in interface org.apache.openjpa.kernel.StoreManager
Copy the given object id value.
copyDate(Date) - Method in interface org.apache.openjpa.util.ProxyManager
Return a copy of the given date with the same information.
copyDate(Date) - Method in class org.apache.openjpa.util.ProxyManagerImpl
 
copyInto(RowImpl, boolean) - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
 
copyInto(RowImpl, boolean) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
Copy all values from this row into the given one.
copyInto(RowImpl, boolean) - Method in class org.apache.openjpa.jdbc.sql.SecondaryRow
 
copyKeyFieldsFromObjectId(Class, FieldConsumer, Object) - Static method in class org.apache.openjpa.enhance.PCRegistry
Copy fields to an outside source from the key fields in the identity object.
copyKeyFieldsToObjectId(Class, FieldSupplier, Object) - Static method in class org.apache.openjpa.enhance.PCRegistry
Copy fields from an outside source to the key fields in the identity object.
copyMap(Map) - Method in interface org.apache.openjpa.util.ProxyManager
Return a new map of the same type as the given one with a copy of all contained key/value pairs.
copyMap(Map) - Method in class org.apache.openjpa.util.ProxyManagerImpl
 
copyMappingInfo(FieldMapping) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Copy mapping info from the given instance to this one.
copyMappingInfo(ValueMapping) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
copyMappingInfo(ValueMapping) - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
Copy mapping info from the given instance to this one.
copyMappingInfo(ValueMapping) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
CopyOnWriteArrayList - Class in org.apache.openjpa.lib.util.concurrent
 
CopyOnWriteArrayList() - Constructor for class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
CopyOnWriteArrayList(Collection) - Constructor for class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
CopyOnWriteArrayList(Object[]) - Constructor for class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
CopyOnWriteArraySet - Class in org.apache.openjpa.lib.util.concurrent
A Set that uses an internal CopyOnWriteArrayList for all of its operations.
CopyOnWriteArraySet() - Constructor for class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArraySet
Creates an empty set.
CopyOnWriteArraySet(Collection) - Constructor for class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArraySet
Creates a set containing all of the elements of the specified collection.
correctName(Table, Column) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Correct the given column's name.
correctRelations(OpenJPAStateManager, FieldMetaData, Object) - Method in class org.apache.openjpa.kernel.InverseManager
Correct relations from the given dirty field to inverse instances.
count(Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
count() - Method in class org.apache.openjpa.jdbc.meta.strats.LRSProxyCollection
 
count(Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return the count of the given value for all matches.
count(Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
count() - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
Return the number of elements in the collection, or Integer.MAX_VALUE.
count() - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
Return the number of entries in the map, or Integer.MAX_VALUE.
cpath - Variable in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
 
create(PersistenceCapable, ClassMetaData) - Static method in class org.apache.openjpa.util.ApplicationIds
Generate an application id based on the current primary key field state of the given instance.
createClasspath() - Method in class org.apache.openjpa.lib.ant.AbstractTask
 
createCodeFormat() - Method in class org.apache.openjpa.ant.ApplicationIdToolTask
Create the embedded code format element.
createCodeFormat() - Method in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
 
createColumns(MetaDataContext, String, Column[], Table, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Retrieve/create columns on the given table by merging the given template information with any user-provided information.
createConfig() - Method in class org.apache.openjpa.lib.ant.AbstractTask
 
createConnectionDecorators() - Method in interface org.apache.openjpa.jdbc.schema.DriverDataSource
Provide any built-in decorators; may be null.
createConnectionDecorators() - Method in class org.apache.openjpa.jdbc.schema.SimpleDriverDataSource
 
createContainerEntityManagerFactory(PersistenceUnitInfo, Map) - Method in class org.apache.openjpa.persistence.PersistenceProviderImpl
 
createEntityManager() - Method in class org.apache.openjpa.persistence.EntityManagerFactoryImpl
 
createEntityManager(Map) - Method in class org.apache.openjpa.persistence.EntityManagerFactoryImpl
 
createEntityManager() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManagerFactory
 
createEntityManager(Map) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManagerFactory
Return an entity manager with the provided additional configuration settings.
createEntityManagerFactory(String, String) - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
Returns a new OpenJPAEntityManagerFactory specified by name in an XML configuration file at the resource location resource.
createEntityManagerFactory(String, String, Map) - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
Returns a new OpenJPAEntityManagerFactory specified by name in an XML configuration file at the resource location resource, applying the properties specified in map as overrides.
createEntityManagerFactory(String, Context) - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
Returns the EntityManagerFactory at the JNDI location specified by jndiLocation in the context context.
createEntityManagerFactory(String, String, Map) - Method in class org.apache.openjpa.persistence.PersistenceProviderImpl
Loads the entity manager specified by name, applying the properties in m as overrides to the properties defined in the XML configuration file for name.
createEntityManagerFactory(String, Map) - Method in class org.apache.openjpa.persistence.PersistenceProviderImpl
 
createEntry(int, Object, Object, ConcurrentHashMap.Entry) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
 
createEntry(HashEntry, int, Object, Object) - Method in class org.apache.openjpa.lib.util.ReferenceHashMap
 
createExtent(Class<T>, boolean) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
createExtent(Class<T>, boolean) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return an extent of the given class, optionally including subclasses.
createFactory(BCClass) - Method in class org.apache.openjpa.enhance.DynamicStorageGenerator
Create a stub factory instance for the given class.
createForeignKey(MetaDataContext, String, List, MappingInfo.ForeignKeyDefaults, Table, ClassMapping, ClassMapping, boolean, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Retrieve/create a foreign key (possibly logical) on the given columns by merging the given template information with any user-provided information.
createIdentityColumn - Variable in class org.apache.openjpa.jdbc.sql.SybaseDictionary
If true, then whenever the schematool creates a table, it will append an additional IDENTITY column to the table's creation SQL.
createIndex(MetaDataContext, String, Index, Column[], boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Retrieve/create an index on the given columns by merging the given template information with any user-provided information.
createIndex(Index, Table) - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Add the given index to the database schema.
createInstance(Class<T>) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
createInstance(Class<T>) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Create a new instance of type cls.
createInteraction() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
createInteraction() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
createInteraction() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
createInverseRelations(StoreContext, Object, Object, FieldMetaData, FieldMetaData[]) - Method in class org.apache.openjpa.kernel.InverseManager
Create the inverse relations for all the given inverse fields.
createMessage(RemoteCommitEvent) - Method in class org.apache.openjpa.event.JMSRemoteCommitProvider
Returns a new Message to send to the topic.
createNamedQuery(String) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
createNamedQuery(String) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
 
createNativeQuery(String) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
createNativeQuery(String, Class) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
createNativeQuery(String, String) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
createNativeQuery(String) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
 
createNativeQuery(String, Class) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
 
createNativeQuery(String, String) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
 
createPrimaryKeys - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
createQuery(String) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
createQuery(String, String) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
createQuery(String) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
 
createQuery(String, String) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Create a new query in the given language.
createSequence(Sequence) - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Add the given sequence to the database schema.
createStatement(boolean) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager.RefCountConnection
 
createStatement(int, int, boolean) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager.RefCountConnection
 
createStatement() - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
createStatement(boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
Create a statement, with the option of not wrapping it in a DelegatingStatement, which is the default.
createStatement(int, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
createStatement(int, int, boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
Create a statement, with the option of not wrapping it in a DelegatingStatement, which is the default.
createStatement(int, int, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
createStatement(int, int, int, boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
createTable(MetaDataContext, MappingInfo.TableDefaults, Schema, String, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Find or generate a table for a mapping.
createTable(Table) - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Add the given table to the database schema.
createUnique(MetaDataContext, String, Unique, Column[], boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Retrieve/create a unique constraint on the given columns by merging the given template information with any user-provided information.
crossJoin(Table, Table) - Method in interface org.apache.openjpa.jdbc.sql.Joins
Perform a cross join on the given tables.
crossJoin(Table, Table) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
crossJoin(Table, Table) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
crossJoinClause - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
ctx - Variable in class org.apache.openjpa.abstractstore.AbstractStoreManager
 
ctx - Variable in class org.apache.openjpa.kernel.AbstractLockManager
The context against which this LockManager is operating.
ctx - Variable in class org.apache.openjpa.kernel.AbstractPCResultObjectProvider
The StoreContext that this result object provider will load objects into.
ctx - Variable in class org.apache.openjpa.kernel.AbstractStoreQuery
 
ctx - Variable in class org.apache.openjpa.kernel.FetchConfigurationImpl.ConfigurationState
 
current - Variable in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSeq
 
current(StoreContext, ClassMetaData) - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSeq
 
current(StoreContext, ClassMetaData) - Method in class org.apache.openjpa.kernel.DelegatingSeq
 
current(StoreContext, ClassMetaData) - Method in interface org.apache.openjpa.kernel.Seq
Return the current value of the sequence, or null if not available.
current(StoreContext, ClassMetaData) - Method in class org.apache.openjpa.kernel.TimeSeededSeq
 
current(StoreContext, ClassMetaData) - Method in class org.apache.openjpa.kernel.UUIDHexSeq
 
current(StoreContext, ClassMetaData) - Method in class org.apache.openjpa.kernel.UUIDStringSeq
 
current() - Method in interface org.apache.openjpa.persistence.Generator
The current sequence value, or null if the sequence does not support current values.
current() - Method in class org.apache.openjpa.persistence.GeneratorImpl
 
currentBackupFile() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
The backup file made for the current file being parsed.
currentClassLoader() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Return the class loader to use when resolving resources and loading classes.
currentClassName() - Method in class org.apache.openjpa.lib.meta.CFMetaDataParser
Return the current class being parsed; the returned name will be fully qualified.
currentComments() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Array of comments for the current node, or empty array if none.
currentDateFunction - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
currentDepth() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Return the parse depth.
currentElement() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Return the current element being parsed.
currentInternal(JDBCStore, ClassMapping) - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSeq
Return the current sequence object.
currentInternal(JDBCStore, ClassMapping) - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
 
currentLocation() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Return the current location within the source file.
currentPackage() - Method in class org.apache.openjpa.lib.meta.CFMetaDataParser
Return the current package being parsed.
currentParent() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Return the tag of the current parent element.
currentQuery() - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
Returns the current string being parsed; used for error messages.
currentStrategy() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Return the current PersistenceStrategy if any.
currentText() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Return the text value within the current node.
currentTimeFunction - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
currentTimestampFunction - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
customDelete(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
customDelete(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
 
customDelete(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
customDelete(OpenJPAStateManager, JDBCStore) - Method in interface org.apache.openjpa.jdbc.meta.Strategy
Override this method to customize flushing this mapping.
customDelete(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractStrategy
 
customDelete(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedFieldStrategy
 
customDelete(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.Version
 
customInsert(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
customInsert(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
 
customInsert(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
customInsert(OpenJPAStateManager, JDBCStore) - Method in interface org.apache.openjpa.jdbc.meta.Strategy
Override this method to customize flushing this mapping.
customInsert(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractStrategy
 
customInsert(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedFieldStrategy
 
customInsert(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy
This method is for class mappings that take over the insert process, but still want to use this indicator for optimistic locking.
customInsert(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.Version
 
customize(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.PropertiesReverseCustomizer
 
customize(FieldMapping) - Method in class org.apache.openjpa.jdbc.meta.PropertiesReverseCustomizer
 
customize(ClassMapping) - Method in interface org.apache.openjpa.jdbc.meta.ReverseCustomizer
Customize the given class information produced by the reverse mapping tool.
customize(FieldMapping) - Method in interface org.apache.openjpa.jdbc.meta.ReverseCustomizer
Customize the given field information produced by the reverse mapping tool.
customizer - Variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool.Flags
 
customizerClass - Variable in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
 
customizerProperties - Variable in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
 
customLoad(JDBCStore, boolean, JDBCFetchConfiguration, long, long) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
customLoad(OpenJPAStateManager, JDBCStore, PCState, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
customLoad(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
customLoad(JDBCStore, boolean, JDBCFetchConfiguration, long, long) - Method in interface org.apache.openjpa.jdbc.meta.ClassStrategy
Implement this method to customize obtaining a result containing all instances of this class.
customLoad(OpenJPAStateManager, JDBCStore, PCState, JDBCFetchConfiguration) - Method in interface org.apache.openjpa.jdbc.meta.ClassStrategy
Implement this method to load the state of a given object, without a previous Result.
customLoad(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result) - Method in interface org.apache.openjpa.jdbc.meta.ClassStrategy
Implement this method to customize loading from a Result into an instance.
customLoad(JDBCStore, boolean, JDBCFetchConfiguration, long, long) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractClassStrategy
 
customLoad(OpenJPAStateManager, JDBCStore, PCState, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractClassStrategy
 
customLoad(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractClassStrategy
 
customUpdate(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
customUpdate(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
 
customUpdate(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
customUpdate(OpenJPAStateManager, JDBCStore) - Method in interface org.apache.openjpa.jdbc.meta.Strategy
Override this method to customize flushing this mapping.
customUpdate(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractStrategy
 
customUpdate(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedFieldStrategy
 
customUpdate(OpenJPAStateManager, JDBCStore, Table, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy
This method is for class mappings that take over the update process, but still want to use this indicator for optimistic locking.
customUpdate(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.Version
 

D

DataCache - Interface in org.apache.openjpa.datacache
Interface that must be implemented by any level 2 cache used by OpenJPA.
DataCache - Annotation Type in org.apache.openjpa.persistence
Caching characteristics for this class.
DataCacheManager - Interface in org.apache.openjpa.datacache
Manages the system's data and query caches.
DataCacheManagerImpl - Class in org.apache.openjpa.datacache
Default data cache manager.
DataCacheManagerImpl() - Constructor for class org.apache.openjpa.datacache.DataCacheManagerImpl
 
dataCacheManagerPlugin - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
DataCachePCData - Interface in org.apache.openjpa.datacache
Specialized PCData implementation for data caching.
DataCachePCDataGenerator - Class in org.apache.openjpa.datacache
A PCDataGenerator instance which generates properly synchronized instances suitable for use in the cache.
DataCachePCDataGenerator(OpenJPAConfiguration) - Constructor for class org.apache.openjpa.datacache.DataCachePCDataGenerator
 
DataCachePCDataGenerator.Timed - Interface in org.apache.openjpa.datacache
Simple interface to give access to expiration time.
DataCachePCDataImpl - Class in org.apache.openjpa.datacache
Specialized PCData implementation for data caching.
DataCachePCDataImpl(Object, ClassMetaData) - Constructor for class org.apache.openjpa.datacache.DataCachePCDataImpl
Constructor.
dataCachePlugin - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
DataCacheScheduler - Class in org.apache.openjpa.datacache
Cron-style cache eviction.
DataCacheScheduler(OpenJPAConfiguration) - Constructor for class org.apache.openjpa.datacache.DataCacheScheduler
 
DataCacheStoreManager - Class in org.apache.openjpa.datacache
StoreManager proxy that delegates to a data cache when possible.
DataCacheStoreManager(StoreManager) - Constructor for class org.apache.openjpa.datacache.DataCacheStoreManager
Constructor.
dataCacheTimeout - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
dataDefinitionCausesTransactionCommit() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
dataDefinitionIgnoredInTransactions() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
DataSourceFactory - Class in org.apache.openjpa.jdbc.schema
Factory for DataSource objects.
DataSourceFactory() - Constructor for class org.apache.openjpa.jdbc.schema.DataSourceFactory
 
DataSourceLogs - Class in org.apache.openjpa.lib.jdbc
Provies basic logging facilities to a DataSource.
DataSourceLogs() - Constructor for class org.apache.openjpa.lib.jdbc.DataSourceLogs
 
DataSourceLogs(Log, Log) - Constructor for class org.apache.openjpa.lib.jdbc.DataSourceLogs
 
datastore - Variable in class org.apache.openjpa.kernel.QueryImpl.Compilation
 
DataStoreId - Annotation Type in org.apache.openjpa.persistence
Describes how to generate a value for a field.
DataStoreIdColumn - Annotation Type in org.apache.openjpa.persistence.jdbc
Surrogate datastore identity column.
DATE - Static variable in class org.apache.openjpa.meta.JavaTypes
 
DateId - Class in org.apache.openjpa.util
OpenJPAId subclass appropriate for Date fields.
DateId(Class, String) - Constructor for class org.apache.openjpa.util.DateId
 
DateId(Class, Date) - Constructor for class org.apache.openjpa.util.DateId
 
DateId(Class, Date) - Constructor for class org.apache.openjpa.util.DateId
 
DateId(Class, Timestamp) - Constructor for class org.apache.openjpa.util.DateId
 
DateId(Class, Date, boolean) - Constructor for class org.apache.openjpa.util.DateId
 
datePrecision - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
dateTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
DAYS - Static variable in class org.apache.openjpa.lib.util.concurrent.TimeUnit
 
DB2Dictionary - Class in org.apache.openjpa.jdbc.sql
Dictionary for IBM DB2 database.
DB2Dictionary() - Constructor for class org.apache.openjpa.jdbc.sql.DB2Dictionary
 
DBDictionary - Class in org.apache.openjpa.jdbc.sql
Class which allows the creation of SQL dynamically, in a database agnostic fashion.
DBDictionary() - Constructor for class org.apache.openjpa.jdbc.sql.DBDictionary
 
DBDictionary.SerializedData - Class in org.apache.openjpa.jdbc.sql
Used by some mappings to represent data that has already been serialized so that we don't have to serialize multiple times.
DBDictionary.SerializedData(byte[]) - Constructor for class org.apache.openjpa.jdbc.sql.DBDictionary.SerializedData
 
DBDictionaryFactory - Class in org.apache.openjpa.jdbc.sql
Factory class to instantiate a dictionary.
DBDictionaryFactory() - Constructor for class org.apache.openjpa.jdbc.sql.DBDictionaryFactory
 
dbdictionaryPlugin - Variable in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
DECI - Static variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
decimalTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
declareClasses(BCClass) - Method in class org.apache.openjpa.enhance.DynamicStorageGenerator
Add interface or superclass declarations to the generated class.
declareClasses(BCClass) - Method in class org.apache.openjpa.enhance.PCDataGenerator
 
declareParameters(String) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
declareParameters(String) - Method in interface org.apache.openjpa.kernel.QueryContext
Declared parameters, for query languages that use them.
declareParameters(String) - Method in class org.apache.openjpa.kernel.QueryImpl
 
decode(String) - Static method in class org.apache.openjpa.lib.util.Base16Encoder
Convert a base16 string into a byte array.
decorate(BCClass, ClassMetaData) - Method in class org.apache.openjpa.datacache.DataCachePCDataGenerator
 
decorate(Object, BCClass, int[]) - Method in class org.apache.openjpa.enhance.DynamicStorageGenerator
Decorate the generated class.
decorate(Object, BCClass, int[]) - Method in class org.apache.openjpa.enhance.PCDataGenerator
 
decorate(BCClass, ClassMetaData) - Method in class org.apache.openjpa.enhance.PCDataGenerator
Apply additional decoration to generated class.
decorate(Connection) - Method in class org.apache.openjpa.jdbc.sql.DB2Dictionary
 
decorate(Connection) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Decorate the given connection if needed.
decorate(Connection) - Method in class org.apache.openjpa.jdbc.sql.InformixDictionary
 
decorate(Connection) - Method in class org.apache.openjpa.jdbc.sql.PostgresDictionary
 
decorate(Connection) - Method in class org.apache.openjpa.jdbc.sql.SybaseDictionary
 
decorate(Connection) - Method in class org.apache.openjpa.lib.jdbc.ConfiguringConnectionDecorator
 
decorate(Connection) - Method in interface org.apache.openjpa.lib.jdbc.ConnectionDecorator
Decorate the given connection if desired.
decorate(Connection) - Method in class org.apache.openjpa.lib.jdbc.JDBCEventConnectionDecorator
 
decorate(Connection) - Method in class org.apache.openjpa.lib.jdbc.LoggingConnectionDecorator
 
decorateDataSource(DataSource, JDBCConfiguration, boolean) - Static method in class org.apache.openjpa.jdbc.schema.DataSourceFactory
Install listeners and base decorators.
decorateResultList(ResultList) - Method in class org.apache.openjpa.kernel.QueryImpl
Optionally decorate the native result.
DecoratingDataSource - Class in org.apache.openjpa.lib.jdbc
Delegating data source that maintains a list of ConnectionDecorators.
DecoratingDataSource(DataSource) - Constructor for class org.apache.openjpa.lib.jdbc.DecoratingDataSource
Constructor.
DEFAULT - Static variable in interface org.apache.openjpa.kernel.FetchConfiguration
Constant to revert any setting back to its default value.
DEFAULT - Static variable in interface org.apache.openjpa.persistence.FetchPlan
Constant to revert any setting to its default value.
DEFAULT_STRING - Static variable in class org.apache.openjpa.meta.ClassMetaData
 
defaultHandler(ValueMapping) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Determine the default handler to use for the given value.
defaultHandler(ValueMapping, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Determine the default handler to use for the given value.
defaultMissingInfo() - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Whether to fill in missing mapping information at runtime with the default values supplied by this plugin.
defaultMissingInfo() - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
defaultMissingInfo() - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
defaultsDataSource(DataSource, String, String) - Static method in class org.apache.openjpa.jdbc.schema.DataSourceFactory
Return a data source with the given user name and password pre-configured as the defaults when DataSource.getConnection() is called.
defaultSourceFile(ClassMetaData) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Return the default file for the given metadata.
defaultSourceFile(QueryMetaData, Map) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Return a default file for the given query.
defaultSourceFile(SequenceMetaData, Map) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Return a default file for the given sequence.
defaultSourceFile(ClassMetaData) - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
 
defaultSourceFile(QueryMetaData, Map) - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
 
defaultSourceFile(SequenceMetaData, Map) - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
 
defaultStrategy(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Determine the default strategy to use for the given class.
defaultStrategy(ClassMapping, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Determine the default strategy to use for the given class.
defaultStrategy(FieldMapping, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Determine the default strategy to use for the given field.
defaultStrategy(FieldMapping, boolean, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Determine the default strategy to use for the given field.
defaultStrategy(Discriminator) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Determine the default strategy to use for the given discriminator.
defaultStrategy(Discriminator, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Determine the default strategy to use for the given discriminator.
defaultStrategy(Version) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Determine the default strategy to use for the given version.
defaultStrategy(Version, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Determine the default strategy to use for the given version.
defaultStrategy(Version, FieldMapping) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Return the default version strategy, given a version field.
defaultTypeStrategy(FieldMapping, boolean, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Return the built-in strategy for the field's type, or null if none.
defineSuperclassFields(boolean) - Method in class org.apache.openjpa.meta.ClassMetaData
Incorporate superclass fields redefined in this subclass into this metadata.
DelegatingBroker - Class in org.apache.openjpa.kernel
Delegating broker that can also perform exception translation for use in facades.
DelegatingBroker(Broker) - Constructor for class org.apache.openjpa.kernel.DelegatingBroker
Constructor; supply delegate.
DelegatingBroker(Broker, RuntimeExceptionTranslator) - Constructor for class org.apache.openjpa.kernel.DelegatingBroker
Constructor; supply delegate and exception translator.
DelegatingBrokerFactory - Class in org.apache.openjpa.kernel
Delegating broker factory that can also perform exception translation for use in facades.
DelegatingBrokerFactory(BrokerFactory) - Constructor for class org.apache.openjpa.kernel.DelegatingBrokerFactory
Constructor; supply delegate.
DelegatingBrokerFactory(BrokerFactory, RuntimeExceptionTranslator) - Constructor for class org.apache.openjpa.kernel.DelegatingBrokerFactory
Constructor; supply delegate and exception translator.
DelegatingCallableStatement - Class in org.apache.openjpa.lib.jdbc
CallableStatement that delegates to an internal statement.
DelegatingCallableStatement(CallableStatement, Connection) - Constructor for class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
DelegatingConnection - Class in org.apache.openjpa.lib.jdbc
Wrapper around an existing connection.
DelegatingConnection(Connection) - Constructor for class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
DelegatingDatabaseMetaData - Class in org.apache.openjpa.lib.jdbc
Wrapper around a DatabaseMetadata instance.
DelegatingDatabaseMetaData(DatabaseMetaData, Connection) - Constructor for class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
DelegatingDataCache - Class in org.apache.openjpa.datacache
Delegating data cache that can also perform exception translation for use in facades.
DelegatingDataCache(DataCache) - Constructor for class org.apache.openjpa.datacache.DelegatingDataCache
Constructor.
DelegatingDataCache(DataCache, RuntimeExceptionTranslator) - Constructor for class org.apache.openjpa.datacache.DelegatingDataCache
 
DelegatingDataSource - Class in org.apache.openjpa.lib.jdbc
Wrapper around an existing data source.
DelegatingDataSource(DataSource) - Constructor for class org.apache.openjpa.lib.jdbc.DelegatingDataSource
Constructor.
DelegatingExtent - Class in org.apache.openjpa.kernel
Delegating extent that also can perform exception translation for use in facades.
DelegatingExtent(Extent) - Constructor for class org.apache.openjpa.kernel.DelegatingExtent
Constructor; supply delegate.
DelegatingExtent(Extent, RuntimeExceptionTranslator) - Constructor for class org.apache.openjpa.kernel.DelegatingExtent
Constructor; supply delegate and exception translator.
DelegatingFetchConfiguration - Class in org.apache.openjpa.kernel
Delegating fetch configuration that can also perform exception translation for use in facades.
DelegatingFetchConfiguration(FetchConfiguration) - Constructor for class org.apache.openjpa.kernel.DelegatingFetchConfiguration
Constructor; supply delegate.
DelegatingFetchConfiguration(FetchConfiguration, RuntimeExceptionTranslator) - Constructor for class org.apache.openjpa.kernel.DelegatingFetchConfiguration
Constructor; supply delegate and exception translator.
DelegatingJDBCFetchConfiguration - Class in org.apache.openjpa.jdbc.kernel
Delegating fetch configuration that can also perform exception transation for use in facades.
DelegatingJDBCFetchConfiguration(JDBCFetchConfiguration) - Constructor for class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
Constructor; supply delegate.
DelegatingJDBCFetchConfiguration(JDBCFetchConfiguration, RuntimeExceptionTranslator) - Constructor for class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
Constructor; supply delegate and exception translator.
DelegatingJoinable - Class in org.apache.openjpa.jdbc.meta
Delegates to another Joinable after doing column translation.
DelegatingJoinable(Joinable, ForeignKey) - Constructor for class org.apache.openjpa.jdbc.meta.DelegatingJoinable
Constructor.
DelegatingJoinable(Joinable, Column[]) - Constructor for class org.apache.openjpa.jdbc.meta.DelegatingJoinable
Constructor.
DelegatingMetaDataFactory - Class in org.apache.openjpa.meta
Base class for factory instances that use a delegate.
DelegatingMetaDataFactory(MetaDataFactory) - Constructor for class org.apache.openjpa.meta.DelegatingMetaDataFactory
Constructor; supply delegate.
DelegatingPreparedStatement - Class in org.apache.openjpa.lib.jdbc
Wrapper around an existing statement.
DelegatingPreparedStatement(PreparedStatement, Connection) - Constructor for class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
DelegatingQuery - Class in org.apache.openjpa.kernel
Delegating query that can also perform exception translation for use in facades.
DelegatingQuery(Query) - Constructor for class org.apache.openjpa.kernel.DelegatingQuery
Constructor; supply delegate.
DelegatingQuery(Query, RuntimeExceptionTranslator) - Constructor for class org.apache.openjpa.kernel.DelegatingQuery
Constructor; supply delegate and exception translator.
DelegatingQueryCache - Class in org.apache.openjpa.datacache
Delegating query cache that can also perform exception translation for use in facades.
DelegatingQueryCache(QueryCache) - Constructor for class org.apache.openjpa.datacache.DelegatingQueryCache
Constructor.
DelegatingQueryCache(QueryCache, RuntimeExceptionTranslator) - Constructor for class org.apache.openjpa.datacache.DelegatingQueryCache
 
DelegatingResultList - Class in org.apache.openjpa.kernel
Delegating result list that can also perform exception translation for use in facades.
DelegatingResultList(ResultList) - Constructor for class org.apache.openjpa.kernel.DelegatingResultList
Constructor; supply delegate.
DelegatingResultList(ResultList, RuntimeExceptionTranslator) - Constructor for class org.apache.openjpa.kernel.DelegatingResultList
Constructor; supply delegate and exception translator.
DelegatingResultList.DelegatingListIterator - Class in org.apache.openjpa.kernel
Delegating iterator that also performs exception translation.
DelegatingResultList.DelegatingListIterator(ListIterator) - Constructor for class org.apache.openjpa.kernel.DelegatingResultList.DelegatingListIterator
Constructor; supply delegate.
DelegatingResultSet - Class in org.apache.openjpa.lib.jdbc
Wrapper around an existing result set.
DelegatingResultSet(ResultSet, Statement) - Constructor for class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
DelegatingSeq - Class in org.apache.openjpa.kernel
Delegating sequence that can also perform exception translation for use in facades.
DelegatingSeq(Seq) - Constructor for class org.apache.openjpa.kernel.DelegatingSeq
Constructor; supply delegate.
DelegatingSeq(Seq, RuntimeExceptionTranslator) - Constructor for class org.apache.openjpa.kernel.DelegatingSeq
Constructor; supply delegate and exception translator.
DelegatingStatement - Class in org.apache.openjpa.lib.jdbc
Wrapper around an existing statement.
DelegatingStatement(Statement, Connection) - Constructor for class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
DelegatingStoreManager - Class in org.apache.openjpa.kernel
Base class for store manager decorators that delegate to another store manager for some operations.
DelegatingStoreManager(StoreManager) - Constructor for class org.apache.openjpa.kernel.DelegatingStoreManager
Constructor.
delete(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
delete(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
 
delete(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
delete(OpenJPAStateManager, JDBCStore, RowManager) - Method in interface org.apache.openjpa.jdbc.meta.Strategy
Set the where values appropriately to delete the proper instance, and set all relations on non-secondary tables as updates.
delete(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractStrategy
 
delete(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.ColumnVersionStrategy
 
delete(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedFieldStrategy
 
delete(OpenJPAStateManager, OpenJPAStateManager, JDBCStore, RowManager, Row) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedFieldStrategy
Delete an embedded object record.
delete(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.FullClassStrategy
 
delete(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
delete(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.MapTableFieldStrategy
 
delete(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.NoneClassStrategy
 
delete(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
delete(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
delete(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyInverseKeyFieldStrategy
 
delete(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyTableFieldStrategy
 
delete(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
delete(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.VerticalClassStrategy
 
delete(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.Version
 
delete(Object, OpCallbacks) - Method in interface org.apache.openjpa.kernel.Broker
Delete the given object.
delete(Object, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
delete(Object, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
deleteAll(Collection, OpCallbacks) - Method in interface org.apache.openjpa.kernel.Broker
Delete the given objects.
deleteAll(Collection, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
deleteAll(Collection, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
deleteAll() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
deleteAll(Object[]) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
deleteAll(Map) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
deleteAll() - Method in interface org.apache.openjpa.kernel.Query
Deletes all of the instances that are satisfied by the query.
deleteAll(Object[]) - Method in interface org.apache.openjpa.kernel.Query
Deletes all of the instances that are satisfied by the query.
deleteAll(Map) - Method in interface org.apache.openjpa.kernel.Query
Deletes all of the instances that are satisfied by the query.
deleteAll() - Method in class org.apache.openjpa.kernel.QueryImpl
 
deleteAll(Object[]) - Method in class org.apache.openjpa.kernel.QueryImpl
 
deleteAll(Map) - Method in class org.apache.openjpa.kernel.QueryImpl
 
deleteInMemory(StoreQuery.Executor, Object[]) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
deleteInMemory(StoreQuery.Executor, Object[]) - Method in interface org.apache.openjpa.kernel.QueryContext
Helper method to delete the objects found by executing a query on the given executor.
deleteInMemory(StoreQuery.Executor, Object[]) - Method in class org.apache.openjpa.kernel.QueryImpl
 
DeleteListener - Interface in org.apache.openjpa.event
Listener for when a persistent instance is deleted.
deleteRow(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Delete the row for this object if the reference foreign key exists.
deleteRow() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
deletesAreDetected(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
Dependent - Annotation Type in org.apache.openjpa.persistence
Dependent field marker.
DEPTH_INFINITE - Static variable in class org.apache.openjpa.meta.FetchGroup
Infinite depth.
DEPTH_INFINITE - Static variable in interface org.apache.openjpa.persistence.FetchPlan
Infinite fetch depth.
DerbyDictionary - Class in org.apache.openjpa.jdbc.sql
Dictionary for Apache Derby (formerly Cloudscape).
DerbyDictionary() - Constructor for class org.apache.openjpa.jdbc.sql.DerbyDictionary
 
derefColumns() - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Deref all columns in this key.
derefColumns() - Method in class org.apache.openjpa.jdbc.schema.LocalConstraint
Deref all columns in this constraint.
deriveKey(JDBCStore, Object) - Method in interface org.apache.openjpa.jdbc.meta.strats.LRSMapFieldStrategy
Some mapping derive keys from map values.
deriveKey(JDBCStore, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.MapTableFieldStrategy
 
deriveKey(JDBCStore, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapInverseKeyFieldStrategy
 
deriveKey(JDBCStore, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapTableFieldStrategy
 
deriveValue(JDBCStore, Object) - Method in interface org.apache.openjpa.jdbc.meta.strats.LRSMapFieldStrategy
Some mapping derive values from map keys.
deriveValue(JDBCStore, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.MapTableFieldStrategy
 
deriveValue(JDBCStore, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapInverseKeyFieldStrategy
 
deriveValue(JDBCStore, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapTableFieldStrategy
 
desc - Variable in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
deserialize(byte[], StoreContext) - Static method in class org.apache.openjpa.util.Serialization
Deserialize an object value from the given bytes.
deserialize(InputStream, StoreContext) - Static method in class org.apache.openjpa.util.Serialization
Deserialize an object value from the given stream.
DESERIALIZED - Static variable in interface org.apache.openjpa.enhance.PersistenceCapable
 
detach(Object, OpCallbacks) - Method in interface org.apache.openjpa.kernel.Broker
Detach the specified object from the broker.
detach(Object, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
detach(Object, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
detach(Object) - Method in class org.apache.openjpa.kernel.DetachManager
Return a detached version of the given instance.
detach(T) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
detach(T) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Detach the specified object from the entity manager.
DETACH_ALL - Static variable in interface org.apache.openjpa.kernel.DetachState
Mode to detach all fields.
DETACH_CLOSE - Static variable in interface org.apache.openjpa.kernel.AutoDetach
Detach context on close.
DETACH_COMMIT - Static variable in interface org.apache.openjpa.kernel.AutoDetach
Detach context on transaction commit.
DETACH_FGS - Static variable in interface org.apache.openjpa.kernel.DetachState
Mode to detach all fields in the current fetch groups.
DETACH_LOADED - Static variable in interface org.apache.openjpa.kernel.DetachState
Mode to detach all currently-loaded fields.
DETACH_NONTXREAD - Static variable in interface org.apache.openjpa.kernel.AutoDetach
Detach context on any nontransctional read, such that each nontransactional operation uses a new persistence context in essence.
detachable - Variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool.Flags
 
detachAll(OpCallbacks) - Method in interface org.apache.openjpa.kernel.Broker
Detach all objects in place.
detachAll(Collection, OpCallbacks) - Method in interface org.apache.openjpa.kernel.Broker
Detach the specified objects from the broker.
detachAll(Collection, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
detachAll(OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
detachAll(Collection, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
detachAll(OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
detachAll(Collection) - Method in class org.apache.openjpa.kernel.DetachManager
Return detached versions of all the given instances.
detachAll(Object...) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
detachAll(Collection) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
detachAll(Collection) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Detach the specified objects from the entity manager.
detachAll(Object...) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Detach the specified objects from the entity manager.
DetachedState - Annotation Type in org.apache.openjpa.persistence
Detached state.
DetachedStateManager - Class in org.apache.openjpa.kernel
Internal state manager for detached instances.
DetachedStateManager(PersistenceCapable, OpenJPAStateManager, BitSet, boolean, boolean) - Constructor for class org.apache.openjpa.kernel.DetachedStateManager
Constructor.
DetachedValueStateManager - Class in org.apache.openjpa.kernel
Implementation of OpenJPAStateManager designed to retrieve values from a detached instance, including when managed by a DetachedStateManager.
DetachedValueStateManager(Object, StoreContext) - Constructor for class org.apache.openjpa.kernel.DetachedValueStateManager
 
DetachedValueStateManager(PersistenceCapable, ClassMetaData, StoreContext) - Constructor for class org.apache.openjpa.kernel.DetachedValueStateManager
 
DetachListener - Interface in org.apache.openjpa.event
Listener for when a persistent instance is detached.
DetachManager - Class in org.apache.openjpa.kernel
Handles detaching instances.
DetachManager(BrokerImpl, boolean, OpCallbacks) - Constructor for class org.apache.openjpa.kernel.DetachManager
Constructor.
DetachOptions - Class in org.apache.openjpa.conf
Detach options.
DetachOptions() - Constructor for class org.apache.openjpa.conf.DetachOptions
 
DetachOptions.All - Class in org.apache.openjpa.conf
Public to allow reflection.
DetachOptions.All() - Constructor for class org.apache.openjpa.conf.DetachOptions.All
 
DetachOptions.FetchGroups - Class in org.apache.openjpa.conf
Public to allow reflection.
DetachOptions.FetchGroups() - Constructor for class org.apache.openjpa.conf.DetachOptions.FetchGroups
 
DetachOptions.Loaded - Class in org.apache.openjpa.conf
Detach loaded state.
DetachOptions.Loaded() - Constructor for class org.apache.openjpa.conf.DetachOptions.Loaded
 
DetachState - Interface in org.apache.openjpa.kernel
Constants for which fields to include in the detach graph.
detachStatePlugin - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
dict - Variable in class org.apache.openjpa.jdbc.kernel.AbstractUpdateManager
 
dict - Variable in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
dict - Variable in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
dir - Variable in class org.apache.openjpa.meta.AbstractMetaDataFactory
 
directory - Variable in class org.apache.openjpa.enhance.ApplicationIdTool.Flags
 
directory - Variable in class org.apache.openjpa.enhance.PCEnhancer.Flags
 
directory - Variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool.Flags
 
dirName - Variable in class org.apache.openjpa.ant.ApplicationIdToolTask
 
dirName - Variable in class org.apache.openjpa.ant.PCEnhancerTask
 
dirName - Variable in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
 
dirty(String) - Method in interface org.apache.openjpa.enhance.StateManager
Make named field dirty.
dirty(String) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
dirty(int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
dirty(int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
dirty(String) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
dirty(String) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
dirty(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
dirty(int) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Mark the given field as dirty.
dirty(String) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
dirty(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
dirty(Object, String) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
dirty(Object, String) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Make the named field of the given object dirty.
dirty(Proxy) - Static method in class org.apache.openjpa.util.Proxies
Used by proxy types to dirty their owner.
dirtyClass(Class) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
dirtyClass(Class) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Mark the given class as dirty within the current transaction.
DirtyListener - Interface in org.apache.openjpa.event
Listener for when a persistent instance becomes dirty.
dirtyType(Class) - Method in interface org.apache.openjpa.kernel.Broker
Mark the given class as dirty within the current transaction.
dirtyType(Class) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
dirtyType(Class) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
disc - Variable in class org.apache.openjpa.jdbc.meta.strats.AbstractDiscriminatorStrategy
The owning discriminator.
Discriminator - Class in org.apache.openjpa.jdbc.meta
Handles determining the object class of database records.
Discriminator(ClassMapping) - Constructor for class org.apache.openjpa.jdbc.meta.Discriminator
Constructor.
DISCRIMINATOR - Static variable in class org.apache.openjpa.jdbc.meta.QueryResultMapping.PCResult
Path token to represent a discriminator.
DiscriminatorMappingInfo - Class in org.apache.openjpa.jdbc.meta
Information about the mapping from a discriminator to the schema, in raw form.
DiscriminatorMappingInfo() - Constructor for class org.apache.openjpa.jdbc.meta.DiscriminatorMappingInfo
 
DiscriminatorStrategy - Interface in org.apache.openjpa.jdbc.meta
Handles determining the object class of database records.
discriminatorStrategy - Variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool.Flags
 
DiscriminatorStrategy - Annotation Type in org.apache.openjpa.persistence.jdbc
Discriminator mapping strategy.
distinct(Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
distinct(Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return distinct values of the given value.
distinct(QueryExpressions, boolean, List) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
Filter the given list of matches, removing duplicate entries.
distinct(Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
distinct - Variable in class org.apache.openjpa.kernel.exps.QueryExpressions
 
DISTINCT_AUTO - Static variable in class org.apache.openjpa.kernel.exps.QueryExpressions
 
DISTINCT_FALSE - Static variable in class org.apache.openjpa.kernel.exps.QueryExpressions
 
DISTINCT_TRUE - Static variable in class org.apache.openjpa.kernel.exps.QueryExpressions
 
distinctCountColumnSeparator - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
distinctTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
divide(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
divide(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return a value representing the first value divided by the first one.
divide(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
divide(Object, Class, Object, Class) - Static method in class org.apache.openjpa.kernel.Filters
Divide the given values.
DocTypeReader - Class in org.apache.openjpa.lib.xml
The DocTypeReader can be used to dynamically include a DOCTYPE declaration in an XML stream.
DocTypeReader(Reader, Reader) - Constructor for class org.apache.openjpa.lib.xml.DocTypeReader
Construct the reader with an XML stream, and set the DOCTYPE information to be included.
doesMaxRowSizeIncludeBlobs() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
doReadObject(ObjectInputStream) - Method in class org.apache.openjpa.lib.util.LRUMap
 
doReadObject(ObjectInputStream) - Method in class org.apache.openjpa.lib.util.ReferenceHashMap
 
doTimedWait(WaitQueue.QueuedSync, long) - Method in class org.apache.openjpa.lib.util.concurrent.WaitQueue.WaitNode
 
DOUBLE - Static variable in class org.apache.openjpa.meta.JavaTypes
 
DOUBLE_OBJ - Static variable in class org.apache.openjpa.meta.JavaTypes
 
doubleTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
DoubleValue - Class in org.apache.openjpa.lib.conf
A double Value.
DoubleValue(String) - Constructor for class org.apache.openjpa.lib.conf.DoubleValue
 
doWait(WaitQueue.QueuedSync) - Method in class org.apache.openjpa.lib.util.concurrent.WaitQueue.WaitNode
 
doWaitUninterruptibly(WaitQueue.QueuedSync) - Method in class org.apache.openjpa.lib.util.concurrent.WaitQueue.WaitNode
 
doWriteObject(ObjectOutputStream) - Method in class org.apache.openjpa.lib.util.LRUMap
 
doWriteObject(ObjectOutputStream) - Method in class org.apache.openjpa.lib.util.ReferenceHashMap
 
DriverDataSource - Interface in org.apache.openjpa.jdbc.schema
A DataSource that allows additional configuration options to be set into it, so that it can wrap a JDBC driver or other DataSource.
driverDataSourcePlugin - Variable in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
driverDeserializesBlobs - Variable in class org.apache.openjpa.jdbc.sql.MySQLDictionary
Whether the driver automatically deserializes blobs.
driverVendor - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
drop(Class[], int, ClassLoader) - Method in class org.apache.openjpa.jdbc.meta.MetaDataPlusMappingFactory
 
drop(Class[], int, ClassLoader) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
 
drop(Class[], int, ClassLoader) - Method in class org.apache.openjpa.meta.AbstractMetaDataFactory
 
drop(Class[], int, ClassLoader) - Method in class org.apache.openjpa.meta.DelegatingMetaDataFactory
 
drop(Class[], int, ClassLoader) - Method in interface org.apache.openjpa.meta.MetaDataFactory
Drop the metadata for the given classes in the given mode(s).
drop(Class[], int, ClassLoader) - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
dropColumn(Column) - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Drop the given column from the database schema.
dropForeignKey(ForeignKey) - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Drop the given foreign key from the database schema.
dropIndex(Index) - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Drop the given index from the database schema.
dropPrimaryKey(PrimaryKey) - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Drop the given primary key from the database schema.
dropSequence() - Method in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
Drops the sequence in the DB.
dropSequence(Sequence) - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Drop the given sequence from the database schema.
dropSequences - Variable in class org.apache.openjpa.jdbc.meta.MappingTool.Flags
 
dropSequences - Variable in class org.apache.openjpa.jdbc.schema.SchemaTool.Flags
 
dropTable() - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
Drops the sequence table in the DB.
dropTable(Table) - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Drop the given table from the database schema.
dropTable() - Method in class org.apache.openjpa.jdbc.schema.TableSchemaFactory
Drops the sequence table in the DB.
dropTables - Variable in class org.apache.openjpa.jdbc.meta.MappingTool.Flags
 
dropTables - Variable in class org.apache.openjpa.jdbc.schema.SchemaTool.Flags
 
dropTableSQL - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
dynamicDataStructs - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
DynamicSchemaFactory - Class in org.apache.openjpa.jdbc.schema
Factory whose schema group dynamically fills itself with information as mappings validate themselves in their map method.
DynamicSchemaFactory() - Constructor for class org.apache.openjpa.jdbc.schema.DynamicSchemaFactory
 
DynamicStorage - Interface in org.apache.openjpa.enhance
Interface for dynamically generated classes.
DynamicStorageGenerator - Class in org.apache.openjpa.enhance
Factory for creating new DynamicStorage classes.
DynamicStorageGenerator() - Constructor for class org.apache.openjpa.enhance.DynamicStorageGenerator
 

E

EAGER_INNER - Static variable in interface org.apache.openjpa.jdbc.sql.Select
Constant indicating to batch the select using an inner join.
EAGER_JOIN - Static variable in class org.apache.openjpa.jdbc.conf.FetchModeValue
 
EAGER_JOIN - Static variable in interface org.apache.openjpa.jdbc.kernel.EagerFetchModes
Constant indicating to load relations and subclass data if possible without separate queries.
EAGER_NONE - Static variable in class org.apache.openjpa.jdbc.conf.FetchModeValue
 
EAGER_NONE - Static variable in interface org.apache.openjpa.jdbc.kernel.EagerFetchModes
Constant indicating not to try to load subclass data and related objects when querying for an object.
EAGER_OUTER - Static variable in interface org.apache.openjpa.jdbc.sql.Select
Constant indicating to batch the select using an outer join.
EAGER_PARALLEL - Static variable in class org.apache.openjpa.jdbc.conf.FetchModeValue
 
EAGER_PARALLEL - Static variable in interface org.apache.openjpa.jdbc.kernel.EagerFetchModes
Constant indicating to load relations and subclass data if possible using either joins or parallel queries.
EAGER_PARALLEL - Static variable in interface org.apache.openjpa.jdbc.sql.Select
Constant indicating to use a separate select executed in parallel.
eagerClone(FieldMapping, int, boolean, int) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
eagerClone(FieldMapping, int, boolean, int) - Method in interface org.apache.openjpa.jdbc.sql.Select
Return a select that will be eagerly executed with this one, or null if the select cannot be created for the given key and join type.
eagerClone(FieldMapping, int, boolean, int) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
eagerFetchMode - Variable in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
EagerFetchMode - Annotation Type in org.apache.openjpa.persistence.jdbc
Determines how to eager-fetch a field.
EagerFetchModes - Interface in org.apache.openjpa.jdbc.kernel
Eager fetch mode constants.
EagerFetchType - Enum in org.apache.openjpa.persistence.jdbc
Type of fetching to employ.
EagerResultList - Class in org.apache.openjpa.lib.rop
Simple, non-lazy ResultList implementation
EagerResultList(ResultObjectProvider) - Constructor for class org.apache.openjpa.lib.rop.EagerResultList
 
ECLEAN - Static variable in class org.apache.openjpa.kernel.PCState
Embedded-Clean
ECOPY - Static variable in class org.apache.openjpa.kernel.PCState
Embedded-Copy
EDELETED - Static variable in class org.apache.openjpa.kernel.PCState
Embedded-Deleted
EDIRTY - Static variable in class org.apache.openjpa.kernel.PCState
Embedded-Dirty
ELEM_ACCESS - Static variable in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
ELEM_ATTRS - Static variable in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
ELEM_CASCADE - Static variable in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
ELEM_CASCADE_ALL - Static variable in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
ELEM_CASCADE_MER - Static variable in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
ELEM_CASCADE_PER - Static variable in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
ELEM_CASCADE_REF - Static variable in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
ELEM_CASCADE_REM - Static variable in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
ELEM_LISTENER - Static variable in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
ELEM_PKG - Static variable in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
ELEM_PU_DEF - Static variable in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
ELEM_PU_META - Static variable in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
element() - Method in interface org.apache.openjpa.lib.util.concurrent.Queue
Retrieves, but does not remove, the head of this queue.
ELEMENT - Static variable in interface org.apache.openjpa.meta.Order
Token denoting to order by the element value.
ElementClassCriteria - Annotation Type in org.apache.openjpa.persistence.jdbc
Marker interface specifying to use the expected class of the array, collection, or map element relation as criteria in the join.
ElementDependent - Annotation Type in org.apache.openjpa.persistence
Dependent array, collection, or map element marker.
ElementForeignKey - Annotation Type in org.apache.openjpa.persistence.jdbc
Foreign key on array, collection, or map element columns.
ElementIndex - Annotation Type in org.apache.openjpa.persistence.jdbc
Index on array, collection, or map element columns.
ElementJoinColumn - Annotation Type in org.apache.openjpa.persistence.jdbc
Array, collection, or map element join column.
ElementJoinColumns - Annotation Type in org.apache.openjpa.persistence.jdbc
Allows the specification of multiple array, collection, or map element columns for compound joins.
ElementNonpolymorphic - Annotation Type in org.apache.openjpa.persistence.jdbc
Indicates that the annotated array, collection, or map's elements are not entirely polymorphic.
ElementType - Annotation Type in org.apache.openjpa.persistence
Indicates the persistent element type of an array, collection, or map field, if different than the declared element type.
EM_KEY - Static variable in class org.apache.openjpa.persistence.OpenJPAPersistence
 
embed(Object, Object, OpenJPAStateManager, ValueMetaData) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
embed(Object, Object, OpenJPAStateManager, ValueMetaData) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
embed(Object, Object, OpenJPAStateManager, ValueMetaData) - Method in interface org.apache.openjpa.kernel.StoreContext
Make the given instance embedded.
Embeddable - Interface in org.apache.openjpa.jdbc.meta
Interface for field strategies that can managed fields of embedded-element, embedded-key, and embedded-value objects.
EmbeddedClassStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Class mapping for embedded objects.
EmbeddedClassStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.EmbeddedClassStrategy
 
EmbeddedMapping - Annotation Type in org.apache.openjpa.persistence.jdbc
Embedded mapping information.
EmbedFieldStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Mapping for an embedded persistent object.
EmbedFieldStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.EmbedFieldStrategy
 
EmbedValueHandler - Class in org.apache.openjpa.jdbc.meta.strats
Base class for embedded value handlers.
EmbedValueHandler() - Constructor for class org.apache.openjpa.jdbc.meta.strats.EmbedValueHandler
 
EMF_KEY - Static variable in class org.apache.openjpa.persistence.OpenJPAPersistence
 
EmpressDictionary - Class in org.apache.openjpa.jdbc.sql
Dictionary for Empress using ODBC server combined with their type 2 driver.
EmpressDictionary() - Constructor for class org.apache.openjpa.jdbc.sql.EmpressDictionary
 
EMPTY - Static variable in class org.apache.openjpa.lib.conf.StringListValue
 
EMPTY - Static variable in class org.apache.openjpa.lib.util.Options
Immutable empty instance.
EMPTY_BOOLEANS - Static variable in interface org.apache.openjpa.kernel.StoreQuery
 
EMPTY_CLASSES - Static variable in interface org.apache.openjpa.kernel.StoreQuery
 
EMPTY_CLASSES - Static variable in class org.apache.openjpa.meta.MetaDataRepository
 
EMPTY_COLUMNS - Static variable in class org.apache.openjpa.jdbc.schema.Schemas
 
EMPTY_COMMENTS - Static variable in interface org.apache.openjpa.lib.xml.Commentable
 
EMPTY_FIELDS - Variable in class org.apache.openjpa.meta.MetaDataRepository
 
EMPTY_FOREIGN_KEYS - Static variable in class org.apache.openjpa.jdbc.schema.Schemas
 
EMPTY_INDEXES - Static variable in class org.apache.openjpa.jdbc.schema.Schemas
 
EMPTY_MAPPINGS - Static variable in class org.apache.openjpa.jdbc.meta.ClassMapping
 
EMPTY_METAS - Static variable in interface org.apache.openjpa.kernel.StoreQuery
 
EMPTY_METAS - Variable in class org.apache.openjpa.meta.MetaDataRepository
 
EMPTY_NON_PERSISTENT - Static variable in class org.apache.openjpa.meta.MetaDataRepository
 
EMPTY_OBJECTS - Static variable in interface org.apache.openjpa.kernel.StoreQuery
 
EMPTY_ORDERS - Variable in class org.apache.openjpa.meta.MetaDataRepository
 
EMPTY_PARAMS - Static variable in interface org.apache.openjpa.kernel.StoreQuery
 
EMPTY_STATES - Static variable in class org.apache.openjpa.jdbc.kernel.exps.QueryExpressionsState
 
EMPTY_STRINGS - Static variable in interface org.apache.openjpa.kernel.StoreQuery
 
EMPTY_THROWABLES - Static variable in class org.apache.openjpa.util.Exceptions
 
EMPTY_UNIQUES - Static variable in class org.apache.openjpa.jdbc.schema.Schemas
 
EMPTY_VALUES - Static variable in class org.apache.openjpa.jdbc.schema.Schemas
 
EMPTY_VALUES - Static variable in class org.apache.openjpa.kernel.exps.QueryExpressions
 
emptyExpression() - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
emptyExpression() - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return a blank expression; this is used when the filter is empty.
emptyExpression() - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
encode(byte[]) - Static method in class org.apache.openjpa.lib.util.Base16Encoder
Convert bytes to a base16 string.
end - Variable in class org.apache.openjpa.kernel.StoreQuery.Range
 
endCDATA() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
 
endClass(String) - Method in class org.apache.openjpa.lib.meta.CFMetaDataParser
End a class.
endClass(String) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
endClassElement(String) - Method in class org.apache.openjpa.lib.meta.CFMetaDataParser
Override this method marking the end of an element within a declared class.
endClassElement(String) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
endClassMapping(ClassMetaData) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingParser
 
endClassMapping(ClassMetaData) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Implement to finalize class mapping.
endClassMappingElement(String) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingParser
 
endClassMappingElement(String) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Implement to parse a mapping element within a class.
endConfiguration() - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
endConfiguration() - Method in class org.apache.openjpa.datacache.AbstractQueryCache
 
endConfiguration() - Method in class org.apache.openjpa.ee.AutomaticManagedRuntime
 
endConfiguration() - Method in class org.apache.openjpa.ee.InvocationManagedRuntime
 
endConfiguration() - Method in class org.apache.openjpa.event.AbstractRemoteCommitProvider
 
endConfiguration() - Method in class org.apache.openjpa.event.JMSRemoteCommitProvider
Subclasses that need to perform actions in Configurable.endConfiguration() must invoke this method.
endConfiguration() - Method in class org.apache.openjpa.event.TCPRemoteCommitProvider
Subclasses that need to perform actions in Configurable.endConfiguration() must invoke this method.
endConfiguration() - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSavepointManager
 
endConfiguration() - Method in class org.apache.openjpa.jdbc.kernel.AbstractUpdateManager
 
endConfiguration() - Method in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
 
endConfiguration() - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
 
endConfiguration() - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
endConfiguration() - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
 
endConfiguration() - Method in class org.apache.openjpa.jdbc.schema.DynamicSchemaFactory
 
endConfiguration() - Method in class org.apache.openjpa.jdbc.schema.FileSchemaFactory
 
endConfiguration() - Method in class org.apache.openjpa.jdbc.schema.LazySchemaFactory
 
endConfiguration() - Method in class org.apache.openjpa.jdbc.schema.TableSchemaFactory
 
endConfiguration() - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
 
endConfiguration() - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
endConfiguration() - Method in class org.apache.openjpa.jdbc.sql.SQLFactoryImpl
 
endConfiguration() - Method in class org.apache.openjpa.jdbc.sql.SybaseDictionary
 
endConfiguration() - Method in class org.apache.openjpa.kernel.InverseManager
 
endConfiguration() - Method in interface org.apache.openjpa.lib.conf.Configurable
Invoked upon completion of bean property configuration for this object.
endConfiguration() - Method in class org.apache.openjpa.meta.MetaDataRepository
 
endConfiguration() - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
 
endConfiguration() - Method in class org.apache.openjpa.util.ProxyManagerImpl
 
endDataRequest() - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
endDataRequest() - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
endDataRequest() - Method in interface org.apache.openjpa.jdbc.sql.Result
Ends a data request.
endDTD() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
 
endElement(String) - Method in class org.apache.openjpa.jdbc.schema.XMLSchemaParser
 
endElement(String) - Method in class org.apache.openjpa.lib.meta.CFMetaDataParser
 
endElement(String, String, String) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
 
endElement(String) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Override this method marking the end of some element.
endElement(String) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
End the current element.
endEmbeddedId() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
endEntity(String) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
 
endFieldMapping(FieldMetaData) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingParser
Extend to set the columns.
endFieldMapping(FieldMetaData) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Implement to finalize field mapping.
endGeneratedValue() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
endId() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
endIdClass() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
endl() - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
endl(int) - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
endl(int, int) - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
endLob() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
endNamedNativeQuery() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
endNamedQuery() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
endOperation() - Method in interface org.apache.openjpa.kernel.Broker
End a logical operation.
endOperation() - Method in class org.apache.openjpa.kernel.BrokerImpl
Mark the operation over.
endOperation() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
endPackage(String) - Method in class org.apache.openjpa.lib.meta.CFMetaDataParser
End a package.
endPackageElement(String) - Method in class org.apache.openjpa.lib.meta.CFMetaDataParser
Override this method marking the end of an element within a declared package.
endQueryHint() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
endSequenceGenerator() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
endsWith(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
endsWith(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return whether the first string ends with the second.
endsWith(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
endSystemElement(String) - Method in class org.apache.openjpa.lib.meta.CFMetaDataParser
Override this method marking the end of an element outside of any package or class.
endSystemElement(String) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
endSystemMappingElement(String) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingParser
 
endSystemMappingElement(String) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Implement to parse a mapping element outside of any class.
endTransaction() - Method in class org.apache.openjpa.kernel.AbstractLockManager
Does nothing by default.
endTransaction(int) - Method in class org.apache.openjpa.kernel.BrokerImpl
End the current transaction, making appropriate state transitions.
endTransaction() - Method in interface org.apache.openjpa.kernel.LockManager
Notification that the current transaction has ended.
endTransaction(Collection, Collection) - Method in class org.apache.openjpa.xmlstore.XMLStore
End the datastore transaction.
EndTransactionListener - Interface in org.apache.openjpa.event
Notified when transactions end.
endVersion() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
enforcePropertyRestrictions - Variable in class org.apache.openjpa.enhance.PCEnhancer.Flags
 
ENHANCE_AWARE - Static variable in class org.apache.openjpa.enhance.PCEnhancer
 
ENHANCE_INTERFACE - Static variable in class org.apache.openjpa.enhance.PCEnhancer
 
ENHANCE_NONE - Static variable in class org.apache.openjpa.enhance.PCEnhancer
 
ENHANCE_OID - Static variable in class org.apache.openjpa.enhance.PCEnhancer
 
ENHANCE_PC - Static variable in class org.apache.openjpa.enhance.PCEnhancer
 
ENONTRANS - Static variable in class org.apache.openjpa.kernel.PCState
Embedded-Nontransactional
ensureDriverVendor() - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
Ensure that the driver vendor has been set, and if not, set it now.
enter(Expression) - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionVisitor
 
enter(Value) - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionVisitor
 
enter(Expression) - Method in interface org.apache.openjpa.kernel.exps.ExpressionVisitor
Enter an expression.
enter(Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionVisitor
Enter a value.
EntityExistsException - Class in org.apache.openjpa.persistence
Conflict with existing entity.
EntityExistsException(String, Throwable[], Object, boolean) - Constructor for class org.apache.openjpa.persistence.EntityExistsException
 
EntityManagerFactoryImpl - Class in org.apache.openjpa.persistence
Implementation of EntityManagerFactory that acts as a facade to a BrokerFactory.
EntityManagerFactoryImpl() - Constructor for class org.apache.openjpa.persistence.EntityManagerFactoryImpl
Default constructor provided for auto-instantiation.
EntityManagerFactoryImpl(BrokerFactory) - Constructor for class org.apache.openjpa.persistence.EntityManagerFactoryImpl
Supply delegate on construction.
EntityManagerFactoryValue - Class in org.apache.openjpa.persistence
Plugin type used to represent the EntityManagerFactory.
EntityManagerFactoryValue() - Constructor for class org.apache.openjpa.persistence.EntityManagerFactoryValue
 
EntityManagerImpl - Class in org.apache.openjpa.persistence
Implementation of EntityManager interface.
EntityManagerImpl(EntityManagerFactoryImpl, Broker) - Constructor for class org.apache.openjpa.persistence.EntityManagerImpl
Constructor; supply factory and delegate.
EntityNotFoundException - Class in org.apache.openjpa.persistence
Missing entity.
EntityNotFoundException(String, Throwable[], Object, boolean) - Constructor for class org.apache.openjpa.persistence.EntityNotFoundException
 
entryAdded(Object, Object) - Method in class org.apache.openjpa.util.CacheMap
Invoked when an entry is added to the cache.
entryRemoved(Object, Object, boolean) - Method in class org.apache.openjpa.util.CacheMap
Invoked when a key-value pair is evicted from this data structure.
entrySet() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
Returns a collection view of the mappings contained in this map.
entrySet() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
Returns a Collection view of the mappings contained in this HashMap.
entrySet() - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
entrySet() - Method in class org.apache.openjpa.util.CacheMap
 
entrySet(ProxyMap, Set, int) - Static method in class org.apache.openjpa.util.Proxies
Return a proxy for the given map key or entry set.
entrySet() - Method in class org.apache.openjpa.util.ProxyHashMap
 
entrySet() - Method in class org.apache.openjpa.util.ProxyHashtable
 
entrySet() - Method in class org.apache.openjpa.util.ProxyProperties
 
entrySet() - Method in class org.apache.openjpa.util.ProxyTreeMap
 
EnumValueHandler - Class in org.apache.openjpa.jdbc.meta.strats
Value handler for JDK1.5 enum field types.
EnumValueHandler() - Constructor for class org.apache.openjpa.jdbc.meta.strats.EnumValueHandler
 
equal(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
equal(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return an expression representing the given condition.
equal(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
equals(Object) - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
equals(Object) - Method in class org.apache.openjpa.datacache.DelegatingQueryCache
 
equals(Object) - Method in class org.apache.openjpa.datacache.QueryKey
Determine equality based on identifying information.
equals(Object) - Method in class org.apache.openjpa.jdbc.sql.Join
 
equals(Object) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
 
equals(Object) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
equals(Object) - Method in class org.apache.openjpa.kernel.DelegatingBrokerFactory
 
equals(Object) - Method in class org.apache.openjpa.kernel.DelegatingExtent
 
equals(Object) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
equals(Object) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
equals(Object) - Method in class org.apache.openjpa.kernel.DelegatingResultList.DelegatingListIterator
 
equals(Object) - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
equals(Object) - Method in class org.apache.openjpa.kernel.DelegatingSeq
 
equals(Object) - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
equals(Object) - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
equals(Object) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
Performs an equality check based on the properties returned from ConfigurationImpl.toProperties(boolean).
equals(Object) - Method in class org.apache.openjpa.lib.conf.Value
 
equals(Object) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
equals(Object) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
equals(Object) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
equals(Object) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDataSource
 
equals(Object) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
equals(Object) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
equals(Object) - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
equals(Object) - Method in class org.apache.openjpa.lib.rop.LazyForwardResultList
 
equals(Object) - Method in class org.apache.openjpa.lib.rop.RandomAccessResultList
 
equals(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap.Entry
 
equals(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashSet
 
equals(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashSet
 
equals(Object) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
equals(Object) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArraySet
Compares the specified object with this set for equality.
equals(Object) - Method in class org.apache.openjpa.lib.util.MultiClassLoader
 
equals(Object) - Method in class org.apache.openjpa.lib.util.ReferenceHashSet
 
equals(Object) - Method in class org.apache.openjpa.meta.ClassMetaData
 
equals(Object) - Method in class org.apache.openjpa.meta.FetchGroup
Affirms equality if the other has the same name and declaring type.
equals(Object) - Method in class org.apache.openjpa.meta.FieldMetaData
 
equals(Object) - Method in class org.apache.openjpa.persistence.EntityManagerFactoryImpl
 
equals(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
equals(Object) - Method in class org.apache.openjpa.persistence.ExtentImpl
 
equals(Object) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
equals(Object) - Method in class org.apache.openjpa.persistence.GeneratorImpl
 
equals(Object) - Method in class org.apache.openjpa.persistence.QueryImpl
 
equals(Object) - Method in class org.apache.openjpa.persistence.QueryResultCacheImpl
 
equals(Object) - Method in class org.apache.openjpa.persistence.StoreCacheImpl
 
equals(Object) - Method in class org.apache.openjpa.util.OpenJPAId
 
equalsColumn(Column) - Method in class org.apache.openjpa.jdbc.schema.Column
Tests compatibility.
equalsForeignKey(ForeignKey) - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Foreign keys are equal if the satisfy the equality constraints of Constraint and they have the same local and primary key columns and action.
equalsIndex(Index) - Method in class org.apache.openjpa.jdbc.schema.Index
Indexes are equal if they have the same name, the same columns, and are both unique/not unique.
equalsLocalConstraint(LocalConstraint) - Method in class org.apache.openjpa.jdbc.schema.LocalConstraint
Return true if the columns of this constraint matches that of the given one.
equalsPrimaryKey(PrimaryKey) - Method in class org.apache.openjpa.jdbc.schema.PrimaryKey
Return true if the structure of this primary key matches that of the given one (same table, same columns).
equalsUnique(Unique) - Method in class org.apache.openjpa.jdbc.schema.Unique
Return true if the structure of this primary key matches that of the given one (same table, same columns).
error(Object) - Method in class org.apache.openjpa.lib.log.AbstractLog
 
error(Object, Throwable) - Method in class org.apache.openjpa.lib.log.AbstractLog
 
error(Object) - Method in class org.apache.openjpa.lib.log.CommonsLogFactory.LogAdapter
 
error(Object, Throwable) - Method in class org.apache.openjpa.lib.log.CommonsLogFactory.LogAdapter
 
ERROR - Static variable in interface org.apache.openjpa.lib.log.Log
 
error(Object) - Method in interface org.apache.openjpa.lib.log.Log
Write out a log message at the Log.ERROR level with the stringification of o as the body of the message, also outputting t to the log.
error(Object, Throwable) - Method in interface org.apache.openjpa.lib.log.Log
Write out a log message at the Log.ERROR level with the stringification of o as the body of the message, also outputting t to the log.
error(Object) - Method in class org.apache.openjpa.lib.log.Log4JLogFactory.LogAdapter
 
error(Object, Throwable) - Method in class org.apache.openjpa.lib.log.Log4JLogFactory.LogAdapter
 
error(Object) - Method in class org.apache.openjpa.lib.log.NoneLogFactory.NoneLog
 
error(Object, Throwable) - Method in class org.apache.openjpa.lib.log.NoneLogFactory.NoneLog
 
error(SAXParseException) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
 
error(SAXParseException) - Method in class org.apache.openjpa.lib.xml.ValidatingErrorHandler
 
ERROR_STR - Static variable in class org.apache.openjpa.lib.log.LogFactoryImpl
 
eval(Object, ExpressionStoreQuery, ExpressionFactory, ClassMetaData) - Method in interface org.apache.openjpa.kernel.exps.ExpressionParser
Parse the given query string.
eval(String[], ExpressionStoreQuery, ExpressionFactory, ClassMetaData) - Method in interface org.apache.openjpa.kernel.exps.ExpressionParser
Parse the given value clauses.
eval(Object, Object, StoreContext, Object[]) - Method in class org.apache.openjpa.kernel.exps.Val
Return this value for the given candidate.
eval(Collection, Object, StoreContext, Object[]) - Method in class org.apache.openjpa.kernel.exps.Val
Return a list of values resulting from evaluating each given candidate.
eval(Object, ExpressionStoreQuery, ExpressionFactory, ClassMetaData) - Method in class org.apache.openjpa.kernel.jpql.JPQLParser
 
eval(String[], ExpressionStoreQuery, ExpressionFactory, ClassMetaData) - Method in class org.apache.openjpa.kernel.jpql.JPQLParser
 
evaluate(Object, Class, Object[], Class[], Object, StoreContext) - Method in class org.apache.openjpa.jdbc.kernel.exps.GetColumn
 
evaluate(ExpContext, Select, String, QueryExpressions, QueryExpressionsState) - Method in class org.apache.openjpa.jdbc.kernel.exps.SelectConstructor
Evaluate the expression, returning a new select and filling in any associated expression state.
evaluate(Object, Class, Object[], Class[], Object, StoreContext) - Method in class org.apache.openjpa.jdbc.kernel.exps.SQLEmbed
 
evaluate(Collection, Class[], Collection, StoreContext) - Method in interface org.apache.openjpa.kernel.exps.AggregateListener
Return the value of this aggregate.
evaluate(Object, Class, Object[], Class[], Object, StoreContext) - Method in interface org.apache.openjpa.kernel.exps.FilterListener
Evaluate the given expression.
evaluate(Object, Class, Object[], Class[], Object, StoreContext) - Method in class org.apache.openjpa.kernel.exps.StringContains
Deprecated.  
evaluate(Object, Object, StoreContext, Object[]) - Method in class org.apache.openjpa.kernel.exps.Val
Return this value as a projection on the given candidate.
evaluate(Collection, Object, StoreContext, Object[]) - Method in class org.apache.openjpa.kernel.exps.Val
Return this value as an aggregate projection on the given group of candidates.
evaluate(Object, Class, Object[], Class[], Object, StoreContext) - Method in class org.apache.openjpa.kernel.exps.WildcardMatch
Deprecated.  
evaluate(Object) - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
evaluate(Object) - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
eventManager - Variable in class org.apache.openjpa.event.AbstractRemoteCommitProvider
 
EventManager - Interface in org.apache.openjpa.lib.util
Basic event manager interface.
eventOccurred(LifecycleEvent) - Method in class org.apache.openjpa.event.AbstractLifecycleListener
Should be implemented to handle the specific lifecycle event.
eventOccurred(TransactionEvent) - Method in class org.apache.openjpa.event.AbstractTransactionListener
Catch-all for unhandled events.
eventOccurred(JDBCEvent) - Method in class org.apache.openjpa.lib.jdbc.AbstractJDBCListener
Catch-all for unhandled events.
evict(DataCache) - Method in class org.apache.openjpa.datacache.DataCacheScheduler
 
evict(Object, OpCallbacks) - Method in interface org.apache.openjpa.kernel.Broker
Evict the given object.
evict(Object, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
evict(Object, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
evict(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
evict(Object) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Evict the given object.
evict(Query) - Method in interface org.apache.openjpa.persistence.QueryResultCache
Evict a query result from the cache.
evict(Query) - Method in class org.apache.openjpa.persistence.QueryResultCacheImpl
 
evict(Class, Object) - Method in interface org.apache.openjpa.persistence.StoreCache
Remove data for the given oid from the cache.
evict(Class, Object) - Method in class org.apache.openjpa.persistence.StoreCacheImpl
 
evictAll(Collection, OpCallbacks) - Method in interface org.apache.openjpa.kernel.Broker
Evict the given objects.
evictAll(OpCallbacks) - Method in interface org.apache.openjpa.kernel.Broker
Evict all clean objects.
evictAll(Extent, OpCallbacks) - Method in interface org.apache.openjpa.kernel.Broker
Evict all persistent-clean and persistent-nontransactional instances in the given Extent.
evictAll(OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
evictAll(Collection, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
evictAll(Extent, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
evictAll(Collection, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
evictAll(OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
evictAll(Extent, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
evictAll(Collection) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
evictAll(Object...) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
evictAll() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
evictAll(Class) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
evictAll(Extent) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
evictAll(Object...) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Evict the given objects.
evictAll(Collection) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Evict the given objects.
evictAll() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Evict all clean objects.
evictAll(Class) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Evict all persistent-clean and persistent-nontransactional instances in the extent of the given class (including subclasses).
evictAll(Extent) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Evict all persistent-clean and persistent-nontransactional instances in the given Extent.
evictAll() - Method in interface org.apache.openjpa.persistence.QueryResultCache
Clear the cache.
evictAll(Class) - Method in interface org.apache.openjpa.persistence.QueryResultCache
Evict all result for queries involving the given class.
evictAll() - Method in class org.apache.openjpa.persistence.QueryResultCacheImpl
 
evictAll(Class) - Method in class org.apache.openjpa.persistence.QueryResultCacheImpl
 
evictAll(Class, Object...) - Method in interface org.apache.openjpa.persistence.StoreCache
Remove data for the given oids from the cache.
evictAll(Class, Collection) - Method in interface org.apache.openjpa.persistence.StoreCache
Remove data for the given oids from the cache.
evictAll() - Method in interface org.apache.openjpa.persistence.StoreCache
Clear the cache.
evictAll(Class, Object...) - Method in class org.apache.openjpa.persistence.StoreCacheImpl
 
evictAll(Class, Collection) - Method in class org.apache.openjpa.persistence.StoreCacheImpl
 
evictAll() - Method in class org.apache.openjpa.persistence.StoreCacheImpl
 
EX_FATAL - Static variable in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
 
EX_UNSUPPORTED - Static variable in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
 
EX_USER - Static variable in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
 
ExceptionInfo - Interface in org.apache.openjpa.util
Interface supplying additional exception information.
ExceptionOrphanedKeyAction - Class in org.apache.openjpa.event
Throw a ObjectNotFoundException when an orphaned key is discovered.
ExceptionOrphanedKeyAction() - Constructor for class org.apache.openjpa.event.ExceptionOrphanedKeyAction
 
Exceptions - Class in org.apache.openjpa.util
Utility methods for externalizing and handling exceptions.
Exceptions() - Constructor for class org.apache.openjpa.util.Exceptions
 
EXCLUDE_ALL - Static variable in interface org.apache.openjpa.kernel.StoreContext
Marker bitset to indicate that all field loads should be excluded in the find methods of this interface.
excludeUnlistedClasses() - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
execute(JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
execute(JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
execute(JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
execute(JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
execute(JDBCStore, JDBCFetchConfiguration) - Method in interface org.apache.openjpa.jdbc.sql.SelectExecutor
Execute this select in the context of the given store manager.
execute(JDBCStore, JDBCFetchConfiguration, int) - Method in interface org.apache.openjpa.jdbc.sql.SelectExecutor
Execute this select in the context of the given store manager.
execute(JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
execute(JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
execute(StoreContext, JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
Execute this select in the context of the given store manager.
execute() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
execute(Map) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
execute(Object[]) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
execute() - Method in interface org.apache.openjpa.kernel.Query
Execute.
execute(Map) - Method in interface org.apache.openjpa.kernel.Query
Execute with parameter map.
execute(Object[]) - Method in interface org.apache.openjpa.kernel.Query
Execute with parameter array.
execute() - Method in class org.apache.openjpa.kernel.QueryImpl
 
execute(Object[]) - Method in class org.apache.openjpa.kernel.QueryImpl
 
execute(Map) - Method in class org.apache.openjpa.kernel.QueryImpl
 
execute() - Method in class org.apache.openjpa.lib.ant.AbstractTask
 
execute(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
execute() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
execute(String, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
execute(String, int[]) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
execute(String, String[]) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
execute(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
execute() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
execute(String, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
execute(String, int[]) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
execute(String, String[]) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
execute(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
execute(String, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
execute(String, int[]) - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
execute(String, String[]) - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
executeBatch() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
executeBatch() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
executeBatch() - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
executeDelete(StoreQuery.Executor, ClassMetaData, ClassMetaData[], boolean, ExpressionFactory[], QueryExpressions[], Object[]) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreQuery
 
executeDelete(StoreQuery, Object[]) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery.AbstractExecutor
 
executeDelete(StoreQuery.Executor, ClassMetaData, ClassMetaData[], boolean, ExpressionFactory[], QueryExpressions[], Object[]) - Method in class org.apache.openjpa.kernel.ExpressionStoreQuery
Execute the given expression against the given candidate extent and delete the instances.
executeDelete(StoreQuery, Object[]) - Method in interface org.apache.openjpa.kernel.StoreQuery.Executor
Deleted the objects that result from the execution of the query, retuning the number of objects that were deleted.
executeExtent(ClassMetaData, boolean, FetchConfiguration) - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
Create a ResultObjectProvider that can return all instances of type, optionally including subclasses as defined by subclasses.
executeExtent(ClassMetaData, boolean, FetchConfiguration) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
executeExtent(ClassMetaData, boolean, FetchConfiguration) - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
executeExtent(ClassMetaData, boolean, FetchConfiguration) - Method in interface org.apache.openjpa.kernel.StoreManager
Return a provider for all instances of the given candidate class, optionally including subclasses.
executeExtent(ClassMetaData, boolean, FetchConfiguration) - Method in class org.apache.openjpa.xmlstore.XMLStoreManager
 
executeOn(String[]) - Method in class org.apache.openjpa.ant.ApplicationIdToolTask
 
executeOn(String[]) - Method in class org.apache.openjpa.ant.MetaDataToolTask
 
executeOn(String[]) - Method in class org.apache.openjpa.ant.PCEnhancerTask
 
executeOn(String[]) - Method in class org.apache.openjpa.jdbc.ant.MappingToolTask
 
executeOn(String[]) - Method in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
 
executeOn(String[]) - Method in class org.apache.openjpa.jdbc.ant.SchemaToolTask
 
executeOn(String[]) - Method in class org.apache.openjpa.lib.ant.AbstractTask
Perform the task action on the given files.
executeQuery(StoreQuery.Executor, ClassMetaData, ClassMetaData[], boolean, ExpressionFactory[], QueryExpressions[], Object[], StoreQuery.Range) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreQuery
 
executeQuery(StoreQuery.Executor, ClassMetaData, ClassMetaData[], boolean, ExpressionFactory[], QueryExpressions[], Object[], StoreQuery.Range) - Method in class org.apache.openjpa.kernel.ExpressionStoreQuery
Execute the given expression against the given candidate extent.
executeQuery(StoreQuery, Object[], StoreQuery.Range) - Method in interface org.apache.openjpa.kernel.StoreQuery.Executor
Return the result of executing this query with the given parameter values.
executeQuery(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
executeQuery(String, boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
Execute the query, with the option of not wrapping it in a DelegatingResultSet, which is the default.
executeQuery() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
executeQuery(boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
Execute the query, with the option of not wrapping it in a DelegatingResultSet, which is the default.
executeQuery(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
executeQuery(String, boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
Execute the query, with the option of not wrapping it in a DelegatingResultSet, which is the default.
executeQuery() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
executeQuery(boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
Execute the query, with the option of not wrapping it in a DelegatingResultSet, which is the default.
executeQuery(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
executeQuery(String, boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
Execute the query, with the option of not wrapping it in a DelegatingResultSet, which is the default.
executeUpdate(StoreQuery.Executor, ClassMetaData, ClassMetaData[], boolean, ExpressionFactory[], QueryExpressions[], Object[]) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreQuery
 
executeUpdate(ClassMetaData, ClassMetaData[], boolean, ExpressionFactory[], QueryExpressions[], Object[]) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreQuery
 
executeUpdate(StoreQuery, Object[]) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery.AbstractExecutor
 
executeUpdate(StoreQuery.Executor, ClassMetaData, ClassMetaData[], boolean, ExpressionFactory[], QueryExpressions[], Object[]) - Method in class org.apache.openjpa.kernel.ExpressionStoreQuery
Execute the given expression against the given candidate extent and updates the instances.
executeUpdate(StoreQuery, Object[]) - Method in interface org.apache.openjpa.kernel.StoreQuery.Executor
Updates the objects that result from the execution of the query, retuning the number of objects that were updated.
executeUpdate(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
executeUpdate() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
executeUpdate(String, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
executeUpdate(String, int[]) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
executeUpdate(String, String[]) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
executeUpdate(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
executeUpdate() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
executeUpdate(String, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
executeUpdate(String, int[]) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
executeUpdate(String, String[]) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
executeUpdate(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
executeUpdate(String, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
executeUpdate(String, int[]) - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
executeUpdate(String, String[]) - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
executeUpdate() - Method in class org.apache.openjpa.persistence.QueryImpl
 
exists(OpenJPAStateManager, Object) - Method in class org.apache.openjpa.datacache.DataCacheStoreManager
 
exists(OpenJPAStateManager, Object) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
exists(OpenJPAStateManager, Object) - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
exists(OpenJPAStateManager, Object) - Method in interface org.apache.openjpa.kernel.StoreManager
Verify that the given instance exists in the data store; return false if it does not.
exists(OpenJPAStateManager, Object) - Method in class org.apache.openjpa.xmlstore.XMLStoreManager
 
exit(Expression) - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionVisitor
 
exit(Value) - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionVisitor
 
exit(Expression) - Method in interface org.apache.openjpa.kernel.exps.ExpressionVisitor
Leave an expression.
exit(Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionVisitor
Leave a value.
ExpContext - Class in org.apache.openjpa.jdbc.kernel.exps
Expression tree context.
ExpContext() - Constructor for class org.apache.openjpa.jdbc.kernel.exps.ExpContext
 
ExpContext(JDBCStore, Object[], JDBCFetchConfiguration) - Constructor for class org.apache.openjpa.jdbc.kernel.exps.ExpContext
 
expectsArguments() - Method in class org.apache.openjpa.jdbc.kernel.exps.GetColumn
 
expectsArguments() - Method in class org.apache.openjpa.jdbc.kernel.exps.SQLEmbed
 
expectsArguments() - Method in interface org.apache.openjpa.kernel.exps.AggregateListener
Return whether this function expects to act on arguments.
expectsArguments() - Method in interface org.apache.openjpa.kernel.exps.FilterListener
Return true if this extension expects arguments to act on.
expectsArguments() - Method in class org.apache.openjpa.kernel.exps.StringContains
Deprecated.  
expectsArguments() - Method in class org.apache.openjpa.kernel.exps.WildcardMatch
Deprecated.  
expectsTarget() - Method in class org.apache.openjpa.jdbc.kernel.exps.GetColumn
 
expectsTarget() - Method in class org.apache.openjpa.jdbc.kernel.exps.SQLEmbed
 
expectsTarget() - Method in interface org.apache.openjpa.kernel.exps.FilterListener
Return true if this extension expects a target to act on.
expectsTarget() - Method in class org.apache.openjpa.kernel.exps.StringContains
Deprecated.  
expectsTarget() - Method in class org.apache.openjpa.kernel.exps.WildcardMatch
Deprecated.  
ExpirationEvent - Class in org.apache.openjpa.datacache
An event indicating the expiration of an object from the data cache, or an expiration of a result list from the query cache.
ExpirationEvent(Object, Object, boolean) - Constructor for class org.apache.openjpa.datacache.ExpirationEvent
Constructor.
ExpirationListener - Interface in org.apache.openjpa.datacache
An entity that wishes to be notified when cache keys expire.
exportMappings(JDBCConfiguration, Class[], boolean, Log, Writer) - Method in interface org.apache.openjpa.jdbc.meta.MappingTool.ImportExport
Export mappings for the given classes based on the given arguments.
Expression - Interface in org.apache.openjpa.kernel.exps
Interface for a set of conditions that must be met for the query to be true.
ExpressionFactory - Interface in org.apache.openjpa.kernel.exps
The ExpressionFactory must be implemented by a particular runtime to form Expressions in its native query language.
ExpressionParser - Interface in org.apache.openjpa.kernel.exps
Parser for query languages that will be used by a ExpressionQuery.
ExpressionStoreQuery - Class in org.apache.openjpa.kernel
Implementation of an expression-based query, which can handle String-based query expressions such as JPQL and JDOQL.
ExpressionStoreQuery(ExpressionParser) - Constructor for class org.apache.openjpa.kernel.ExpressionStoreQuery
Construct a query with a parser for the language.
ExpressionVisitor - Interface in org.apache.openjpa.kernel.exps
Visits nodes of a query expression tree.
ExpState - Class in org.apache.openjpa.jdbc.kernel.exps
Expression tree state.
ExpState() - Constructor for class org.apache.openjpa.jdbc.kernel.exps.ExpState
 
ExpState(Joins) - Constructor for class org.apache.openjpa.jdbc.kernel.exps.ExpState
 
extendsDec(int) - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
Extensions - Class in org.apache.openjpa.meta
Vendor extensions.
Extensions() - Constructor for class org.apache.openjpa.meta.Extensions
 
Extent - Interface in org.apache.openjpa.kernel
Representation of all members of a persistent class.
Extent<T> - Interface in org.apache.openjpa.persistence
An extent is a logical view of all instances of a class.
ExtentImpl - Class in org.apache.openjpa.kernel
Representation of all members of a persistent class.
ExtentImpl<T> - Class in org.apache.openjpa.persistence
An extent is a logical view of all instances of a class.
ExtentImpl(EntityManagerImpl, Extent) - Constructor for class org.apache.openjpa.persistence.ExtentImpl
Constructor; supply delegate.
extentIterator(Class, boolean, FetchConfiguration, boolean) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
extentIterator(Class, boolean, FetchConfiguration, boolean) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
extentIterator(Class, boolean, FetchConfiguration, boolean) - Method in interface org.apache.openjpa.kernel.StoreContext
Return an iterator over all instances of the given type.
Externalizer - Annotation Type in org.apache.openjpa.persistence
Declares a method that transforms the field value to its datastore equivalent.
ExternalValues - Annotation Type in org.apache.openjpa.persistence
Maps field values to their datastore equivalents.
extract() - Method in class org.apache.openjpa.lib.util.concurrent.WaitQueue
 

F

factory - Variable in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
 
Factory - Annotation Type in org.apache.openjpa.persistence
Declares a method that transforms the datastore value to its field equivalent.
FALSE - Static variable in class org.apache.openjpa.persistence.jdbc.AnnotationPersistenceMappingParser
 
FALSE - Static variable in annotation type org.apache.openjpa.persistence.jdbc.EmbeddedMapping
 
fatal(Object) - Method in class org.apache.openjpa.lib.log.AbstractLog
 
fatal(Object, Throwable) - Method in class org.apache.openjpa.lib.log.AbstractLog
 
fatal(Object) - Method in class org.apache.openjpa.lib.log.CommonsLogFactory.LogAdapter
 
fatal(Object, Throwable) - Method in class org.apache.openjpa.lib.log.CommonsLogFactory.LogAdapter
 
FATAL - Static variable in interface org.apache.openjpa.lib.log.Log
 
fatal(Object) - Method in interface org.apache.openjpa.lib.log.Log
Write out a log message at the Log.FATAL level with the stringification of o as the body of the message, also outputting t to the log.
fatal(Object, Throwable) - Method in interface org.apache.openjpa.lib.log.Log
Write out a log message at the Log.FATAL level with the stringification of o as the body of the message, also outputting t to the log.
fatal(Object) - Method in class org.apache.openjpa.lib.log.Log4JLogFactory.LogAdapter
 
fatal(Object, Throwable) - Method in class org.apache.openjpa.lib.log.Log4JLogFactory.LogAdapter
 
fatal(Object) - Method in class org.apache.openjpa.lib.log.NoneLogFactory.NoneLog
 
fatal(Object, Throwable) - Method in class org.apache.openjpa.lib.log.NoneLogFactory.NoneLog
 
FATAL_STR - Static variable in class org.apache.openjpa.lib.log.LogFactoryImpl
 
fatalError(SAXParseException) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
 
fatalError(SAXParseException) - Method in class org.apache.openjpa.lib.xml.ValidatingErrorHandler
 
fetch - Variable in class org.apache.openjpa.jdbc.kernel.exps.ExpContext
Fetch configuration.
fetch(int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
fetch(int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
fetch(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetch(int) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return the externalized value of the field with the given index as an object.
fetch(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
FetchAttribute - Annotation Type in org.apache.openjpa.persistence
Includes a persistent attribute in a FetchGroup.
fetchBatchSize - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
fetchBatchSize - Variable in class org.apache.openjpa.kernel.FetchConfigurationImpl.ConfigurationState
 
fetchBoolean(int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
fetchBoolean(int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
fetchBoolean(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetchBoolean(int) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return the external value of the given field.
fetchBoolean(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
fetchBooleanField(int) - Method in interface org.apache.openjpa.enhance.FieldSupplier
Return the value of the given field.
fetchBooleanField(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetchBooleanField(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
fetchByte(int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
fetchByte(int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
fetchByte(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetchByte(int) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return the external value of the given field.
fetchByte(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
fetchByteField(int) - Method in interface org.apache.openjpa.enhance.FieldSupplier
Return the value of the given field.
fetchByteField(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetchByteField(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
fetchChar(int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
fetchChar(int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
fetchChar(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetchChar(int) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return the external value of the given field.
fetchChar(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
fetchCharField(int) - Method in interface org.apache.openjpa.enhance.FieldSupplier
Return the value of the given field.
fetchCharField(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetchCharField(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
FetchConfiguration - Interface in org.apache.openjpa.kernel
Allows configuration and optimization of how objects are loaded from the data store.
FetchConfigurationImpl - Class in org.apache.openjpa.kernel
Allows configuration and optimization of how objects are loaded from the data store.
FetchConfigurationImpl() - Constructor for class org.apache.openjpa.kernel.FetchConfigurationImpl
 
FetchConfigurationImpl(FetchConfigurationImpl.ConfigurationState) - Constructor for class org.apache.openjpa.kernel.FetchConfigurationImpl
 
FetchConfigurationImpl.ConfigurationState - Class in org.apache.openjpa.kernel
Configurable state shared throughout a traversal chain.
FetchConfigurationImpl.ConfigurationState() - Constructor for class org.apache.openjpa.kernel.FetchConfigurationImpl.ConfigurationState
 
fetchDirection - Variable in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
fetchDouble(int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
fetchDouble(int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
fetchDouble(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetchDouble(int) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return the external value of the given field.
fetchDouble(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
fetchDoubleField(int) - Method in interface org.apache.openjpa.enhance.FieldSupplier
Return the value of the given field.
fetchDoubleField(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetchDoubleField(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
fetchField(int, boolean) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
fetchField(int, boolean) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
fetchField(int, boolean) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetchField(int, boolean) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return the value of the field with the given index as an object.
fetchField(int, boolean) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
fetchFloat(int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
fetchFloat(int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
fetchFloat(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetchFloat(int) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return the external value of the given field.
fetchFloat(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
fetchFloatField(int) - Method in interface org.apache.openjpa.enhance.FieldSupplier
Return the value of the given field.
fetchFloatField(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetchFloatField(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
fetchFromDetachedSM(DetachedStateManager, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
FetchGroup - Class in org.apache.openjpa.meta
Captures fetch group metadata.
FetchGroup - Annotation Type in org.apache.openjpa.persistence
Fetch group definition.
fetchGroups - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
fetchGroups - Variable in class org.apache.openjpa.kernel.FetchConfigurationImpl.ConfigurationState
 
FetchGroups - Annotation Type in org.apache.openjpa.persistence
Fetch groups holder.
fetchInitialField(int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
fetchInitialField(int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
fetchInitialField(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetchInitialField(int) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return the value of the field at the specified index as of the beginning of the transaction.
fetchInitialField(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
fetchInt(int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
fetchInt(int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
fetchInt(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetchInt(int) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return the external value of the given field.
fetchInt(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
fetchIntField(int) - Method in interface org.apache.openjpa.enhance.FieldSupplier
Return the value of the given field.
fetchIntField(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetchIntField(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
fetchLong(int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
fetchLong(int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
fetchLong(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetchLong(int) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return the external value of the given field.
fetchLong(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
fetchLongField(int) - Method in interface org.apache.openjpa.enhance.FieldSupplier
Return the value of the given field.
fetchLongField(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetchLongField(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
FetchModeValue - Class in org.apache.openjpa.jdbc.conf
Value type used to represent fetch modes.
FetchModeValue(String) - Constructor for class org.apache.openjpa.jdbc.conf.FetchModeValue
 
fetchObject(int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
fetchObject(int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
fetchObject(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetchObject(int) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return the external value of the given field.
fetchObject(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
fetchObjectField(int) - Method in interface org.apache.openjpa.enhance.FieldSupplier
Return the value of the given field.
fetchObjectField(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetchObjectField(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
fetchObjectId() - Method in interface org.apache.openjpa.enhance.StateManager
Return the object id, assigning it if necessary.
fetchObjectId() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
fetchObjectId() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
fetchObjectId() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetchObjectId() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
fetchPaths - Variable in class org.apache.openjpa.kernel.exps.QueryExpressions
 
FetchPlan - Interface in org.apache.openjpa.persistence
The fetch plan allows you to dynamically alter eager fetching configuration and other aspects of data loading.
FetchPlanImpl - Class in org.apache.openjpa.persistence
Implements FetchPlan via delegation to FetchConfiguration.
FetchPlanImpl(FetchConfiguration) - Constructor for class org.apache.openjpa.persistence.FetchPlanImpl
Constructor; supply delegate.
fetchShort(int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
fetchShort(int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
fetchShort(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetchShort(int) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return the external value of the given field.
fetchShort(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
fetchShortField(int) - Method in interface org.apache.openjpa.enhance.FieldSupplier
Return the value of the given field.
fetchShortField(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetchShortField(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
fetchString(int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
fetchString(int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
fetchString(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetchString(int) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return the external value of the given field.
fetchString(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
fetchStringField(int) - Method in interface org.apache.openjpa.enhance.FieldSupplier
Return the value of the given field.
fetchStringField(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
fetchStringField(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
field - Variable in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
The owning field mapping.
FieldConsumer - Interface in org.apache.openjpa.enhance
Consumes persistent field values.
FieldManager - Interface in org.apache.openjpa.enhance
Manages persistent fields.
FieldMapping - Class in org.apache.openjpa.jdbc.meta
Specialization of metadata for relational databases.
FieldMapping(String, Class, ClassMapping) - Constructor for class org.apache.openjpa.jdbc.meta.FieldMapping
Constructor.
FieldMappingInfo - Class in org.apache.openjpa.jdbc.meta
Information about the mapping from a field to the schema, in raw form.
FieldMappingInfo() - Constructor for class org.apache.openjpa.jdbc.meta.FieldMappingInfo
 
FieldMetaData - Class in org.apache.openjpa.meta
Metadata for a managed class field.
FieldMetaData(String, Class, ClassMetaData) - Constructor for class org.apache.openjpa.meta.FieldMetaData
Constructor.
fieldName(String) - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
fields - Variable in class org.apache.openjpa.kernel.FetchConfigurationImpl.ConfigurationState
 
FieldStrategy - Interface in org.apache.openjpa.jdbc.meta
Maps a persistent field to the relational schema.
FieldSupplier - Interface in org.apache.openjpa.enhance
Supplies persistent field values.
file - Variable in class org.apache.openjpa.jdbc.ant.MappingToolTask
 
file - Variable in class org.apache.openjpa.jdbc.ant.SchemaToolTask
 
file - Variable in class org.apache.openjpa.meta.MetaDataTool.Flags
 
FileMetaDataIterator - Class in org.apache.openjpa.lib.meta
Iterator over a file, or over all metadata resources below a given directory.
FileMetaDataIterator(File) - Constructor for class org.apache.openjpa.lib.meta.FileMetaDataIterator
Constructor; supply metadata file.
FileMetaDataIterator(File, MetaDataFilter) - Constructor for class org.apache.openjpa.lib.meta.FileMetaDataIterator
Constructor; supply root of directory tree to search and optional file filter.
fileName - Variable in class org.apache.openjpa.ant.MetaDataToolTask
 
Files - Class in org.apache.openjpa.lib.util
Utility operations on files.
Files() - Constructor for class org.apache.openjpa.lib.util.Files
 
files - Variable in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
 
FileSchemaFactory - Class in org.apache.openjpa.jdbc.schema
Factory that uses an XML schema file to construct the system schema.
FileSchemaFactory() - Constructor for class org.apache.openjpa.jdbc.schema.FileSchemaFactory
 
fileSets - Variable in class org.apache.openjpa.lib.ant.AbstractTask
 
FileValue - Class in org.apache.openjpa.lib.conf
A File Value.
FileValue(String) - Constructor for class org.apache.openjpa.lib.conf.FileValue
 
filter - Variable in class org.apache.openjpa.jdbc.kernel.exps.QueryExpressionsState
 
filter - Variable in class org.apache.openjpa.kernel.exps.QueryExpressions
 
FilterListener - Interface in org.apache.openjpa.kernel.exps
A filter listener extends expression filters with custom functionality.
filterListenerPlugins - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
Filters - Class in org.apache.openjpa.kernel
Helper methods for dealing with query filters.
Filters() - Constructor for class org.apache.openjpa.kernel.Filters
 
FilterValue - Interface in org.apache.openjpa.jdbc.kernel.exps
The simplified public view of any non-operator in a query filter, including constants, variables, and object fields.
finalize() - Method in class org.apache.openjpa.kernel.BrokerImpl
Close on finalize.
finalize() - Method in class org.apache.openjpa.lib.rop.AbstractResultList
 
finalize() - Method in class org.apache.openjpa.lib.rop.ResultObjectProviderIterator
 
find(Object, ValueMapping, JDBCFetchConfiguration) - Method in interface org.apache.openjpa.jdbc.kernel.JDBCStore
Find the object with the given oid.
find(Object, ValueMapping, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
Find the object with the given oid.
find(Object, boolean, FindCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
find(Object, FetchConfiguration, BitSet, Object, int) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
find(Object, FetchConfiguration, BitSet, Object, int, FindCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
Internal finder.
find(Object, boolean, FindCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
find(Object, FetchConfiguration, BitSet, Object, int) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
find(Object, boolean, FindCallbacks) - Method in interface org.apache.openjpa.kernel.StoreContext
Find the persistence object with the given oid.
find(Object, FetchConfiguration, BitSet, Object, int) - Method in interface org.apache.openjpa.kernel.StoreContext
Return the object with the given oid.
find(Class<T>, Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
findAll(Collection, boolean, FindCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
findAll(Collection, FetchConfiguration, BitSet, Object, int) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
findAll(Collection, FetchConfiguration, BitSet, Object, int, FindCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
Internal finder.
findAll(Collection, boolean, FindCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
findAll(Collection, FetchConfiguration, BitSet, Object, int) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
findAll(Collection, boolean, FindCallbacks) - Method in interface org.apache.openjpa.kernel.StoreContext
Return the objects with the given oids.
findAll(Collection, FetchConfiguration, BitSet, Object, int) - Method in interface org.apache.openjpa.kernel.StoreContext
Return the objects with the given oids.
findAll(Class<T>, Object...) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
findAll(Class<T>, Collection) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
findAll(Class<T>, Object...) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return the objects with the given oids.
findAll(Class<T>, Collection) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return the objects with the given oids.
findBroker(String, String, boolean) - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
Find a pooled broker, or return null if none.
findCached(Object, FindCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
findCached(Object, FindCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
findCached(Object, FindCallbacks) - Method in interface org.apache.openjpa.kernel.StoreContext
Return the cached instance for the given oid/object, or null if not cached.
findCached(Class<T>, Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
findCached(Class<T>, Object) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return the cached instance for the given oid/object, or null if not cached.
FindCallbacks - Interface in org.apache.openjpa.kernel
Allows facades to control the particulars of the find operation through callbacks.
findClass(String) - Method in class org.apache.openjpa.lib.util.MultiClassLoader
 
findColumn(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
findExportedForeignKeys(PrimaryKey) - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Find all foreign keys exported by a given primary key (all foreign keys that link to the primary key).
findObject(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
Return the 1-based result set index for the given column or id, or a non-positive number if the column is not contained in this result.
findObject(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
findOptionsFor(Class) - Static method in class org.apache.openjpa.lib.util.Options
Finds all the options that can be set on the provided class.
findResource(String) - Method in class org.apache.openjpa.lib.util.MultiClassLoader
 
findResources(String) - Method in class org.apache.openjpa.lib.util.MultiClassLoader
 
findSequence(String) - Method in class org.apache.openjpa.jdbc.schema.LazySchemaFactory
 
findSequence(Sequence) - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Find the equivalent of the given sequence in this schema group.
findSequence(String) - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Find the sequence with the given name in the group, using '.' as the catalog separator.
findTable(String) - Method in class org.apache.openjpa.jdbc.schema.DynamicSchemaFactory
 
findTable(String) - Method in class org.apache.openjpa.jdbc.schema.LazySchemaFactory
 
findTable(Table) - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Find the equivalent of the given table in this schema group.
findTable(String) - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Find the table with the given name in the group, using '.' as the catalog separator.
findTargetField(Column[], String) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingInfo
Return the position of the template column with the given target field.
findTransactionalBroker(String, String) - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
Find a managed runtime broker associated with the current transaction, or returns null if none.
finish(PCDataGenerator.DynamicPCData, ClassMetaData) - Method in class org.apache.openjpa.datacache.DataCachePCDataGenerator
 
finish(PCDataGenerator.DynamicPCData, ClassMetaData) - Method in class org.apache.openjpa.enhance.PCDataGenerator
Perform any final actions before the pcdata is returned to client code.
finish() - Method in class org.apache.openjpa.jdbc.schema.XMLSchemaParser
Parse the schema relating to the given class.
finish() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Override this method to finish up after a parse; this is only called if no errors are encountered during parsing.
FirebirdDictionary - Class in org.apache.openjpa.jdbc.sql
Dictionary for Firebird.
FirebirdDictionary() - Constructor for class org.apache.openjpa.jdbc.sql.FirebirdDictionary
 
fireEvent(Object, Object) - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
fireEvent(Object, Object) - Method in class org.apache.openjpa.datacache.AbstractQueryCache
 
fireEvent(RemoteCommitEvent) - Method in class org.apache.openjpa.event.AbstractRemoteCommitProvider
Fire a remote commit event via the cached event manager.
fireEvent(Object, ClassMetaData, int) - Method in class org.apache.openjpa.event.LifecycleEventManager
Fire lifecycle event to all registered listeners without an argument.
fireEvent(Object, Object, ClassMetaData, int) - Method in class org.apache.openjpa.event.LifecycleEventManager
Fire lifecycle event to all registered listeners.