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.conf.QueryCompilationCacheValue
 
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(byte[], byte[]) - Static method in class org.apache.openjpa.lib.util.Bytes
Appends two bytes array into one.
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.
areEqual(byte[], byte[]) - Static method in class org.apache.openjpa.lib.util.Bytes
Compares two byte arrays for equality.
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
 
Bytes - Class in org.apache.openjpa.lib.util
This class came from the Apache Commons Id sandbox project in support of the UUIDGenerator implementation.

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.
cast(EntityManager) - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
Return the OpenJPA facade to the given entity manager.
cast(Query) - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
Return the OpenJPA facade to the given query.
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.meta.MetaDataInheritanceComparator
 
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(byte[], byte[]) - Static method in class org.apache.openjpa.lib.util.Bytes
Compares two byte arrays as specified by Comparable.
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
 
compilationFromCache() - Method in class org.apache.openjpa.kernel.QueryImpl
Find the cached compilation for the current query, creating one if it does not exist.
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(AbstractHashedMap.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(Query) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
createQuery(String) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
 
createQuery(Query) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Create a new query from the given one.
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.ee.WASManagedRuntime
EndConfiguration stub.
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
 
endQueryString() - 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 - Exception in org.apache.openjpa.persistence
Conflict with existing entity.
EntityExistsException(String, Throwable[], Object, boolean) - Constructor for exception 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 - Exception in org.apache.openjpa.persistence
Missing entity.
EntityNotFoundException(String, Throwable[], Object, boolean) - Constructor for exception 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.
fireEvent(Object, Object) - Method in class org.apache.openjpa.event.RemoteCommitEventManager
 
fireEvent(Object, Object) - Method in class org.apache.openjpa.event.TransactionEventManager
Fire the given event to all registered listeners.
fireEvent(Object, Object) - Method in class org.apache.openjpa.lib.jdbc.JDBCEventConnectionDecorator
Fire the given event to all listeners.
fireEvent(Object) - Method in class org.apache.openjpa.lib.util.AbstractEventManager
Fire the given event to all listeners.
fireEvent(Object, Object) - Method in class org.apache.openjpa.lib.util.AbstractEventManager
Implement this method to fire the given event to the given listener.
fireEvent(Object) - Method in class org.apache.openjpa.lib.util.concurrent.AbstractConcurrentEventManager
Fire the given event to all listeners.
fireEvent(Object, Object) - Method in class org.apache.openjpa.lib.util.concurrent.AbstractConcurrentEventManager
Implement this method to fire the given event to the given listener.
fireEvent(Object) - Method in interface org.apache.openjpa.lib.util.EventManager
Fire the given event to all listeners, returning any exceptions.
first() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
fixedSizeTypeNames - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
fixedSizeTypeNameSet - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
FLAG_DIRECT_INSERT - Static variable in class org.apache.openjpa.jdbc.schema.Column
 
FLAG_DIRECT_UPDATE - Static variable in class org.apache.openjpa.jdbc.schema.Column
 
FLAG_FK_INSERT - Static variable in class org.apache.openjpa.jdbc.schema.Column
 
FLAG_FK_UPDATE - Static variable in class org.apache.openjpa.jdbc.schema.Column
 
FLAG_PK_JOIN - Static variable in class org.apache.openjpa.jdbc.schema.Column
 
FLAG_UNINSERTABLE - Static variable in class org.apache.openjpa.jdbc.schema.Column
 
FLAG_UNUPDATABLE - Static variable in class org.apache.openjpa.jdbc.schema.Column
 
flags - Variable in class org.apache.openjpa.ant.ApplicationIdToolTask
 
flags - Variable in class org.apache.openjpa.ant.MetaDataToolTask
 
flags - Variable in class org.apache.openjpa.ant.PCEnhancerTask
 
flags - Variable in class org.apache.openjpa.jdbc.ant.MappingToolTask
 
flags - Variable in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
 
flags - Variable in class org.apache.openjpa.jdbc.ant.SchemaToolTask
 
flags - Variable in class org.apache.openjpa.jdbc.sql.RowImpl
 
FlatClassStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Mapping for classes mapped to their superclass table.
FlatClassStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.FlatClassStrategy
 
FLOAT - Static variable in class org.apache.openjpa.meta.JavaTypes
 
FLOAT_OBJ - Static variable in class org.apache.openjpa.meta.JavaTypes
 
floatTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
flush(Collection) - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
Breaks down states based on the objects' current states, and delegates to AbstractStoreManager.flush(Collection,Collection,Collection,Collection,Collection).
flush(Collection, Collection, Collection, Collection, Collection) - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
Responsible for writing modifications happened back to the data store.
flush(Collection) - Method in class org.apache.openjpa.datacache.DataCacheStoreManager
 
flush(Collection, JDBCStore) - Method in class org.apache.openjpa.jdbc.kernel.AbstractUpdateManager
 
flush(RowManager, PreparedStatementManager, Collection) - Method in class org.apache.openjpa.jdbc.kernel.AbstractUpdateManager
Flush all rows of the given row manager.
flush(Collection) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
flush(RowManager, PreparedStatementManager, Collection) - Method in class org.apache.openjpa.jdbc.kernel.OperationOrderUpdateManager
 
flush(Collection, PreparedStatementManager) - Method in class org.apache.openjpa.jdbc.kernel.OperationOrderUpdateManager
Flush the given collection of secondary rows.
flush(RowImpl) - Method in interface org.apache.openjpa.jdbc.kernel.PreparedStatementManager
Flush the given row.
flush() - Method in interface org.apache.openjpa.jdbc.kernel.PreparedStatementManager
This method must be called after the last row has been flushed, to flush any remaining statements.
flush(Collection, JDBCStore) - Method in interface org.apache.openjpa.jdbc.kernel.UpdateManager
Flush the given instances to the data store.
flush(PreparedStatement, DBDictionary, JDBCStore) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
Flush the row's values to the given prepared statement.
flush(PreparedStatement, int, DBDictionary, JDBCStore) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
Flush the row's values to the given prepared statement.
flush() - Method in interface org.apache.openjpa.kernel.Broker
Flush all transactional instances to the data store.
flush() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
flush(int) - Method in class org.apache.openjpa.kernel.BrokerImpl
Flush the transactional state to the data store.
flush() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
flush(Collection) - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
flush(Collection) - Method in interface org.apache.openjpa.kernel.StoreManager
Flush the given state manager collection to the datastore, returning a collection of exceptions encountered during flushing.
flush() - Method in class org.apache.openjpa.lib.log.LogOutputStream
 
flush() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
flush(Collection, Collection, Collection, Collection, Collection) - Method in class org.apache.openjpa.xmlstore.XMLStoreManager
 
FLUSH_COMMIT - Static variable in class org.apache.openjpa.kernel.BrokerImpl
Flush in preparation of commit.
FLUSH_FALSE - Static variable in interface org.apache.openjpa.kernel.QueryFlushModes
Constant denoting that queries should never flush data to the database automatically before executing a query, but should instead execute queries in-memory if necessary.
FLUSH_INC - Static variable in class org.apache.openjpa.kernel.BrokerImpl
Incremental flush.
FLUSH_LOGICAL - Static variable in class org.apache.openjpa.kernel.BrokerImpl
Run persistence-by-reachability and other flush-time operations without accessing the database.
FLUSH_ROLLBACK - Static variable in class org.apache.openjpa.kernel.BrokerImpl
Flush to check consistency of cache, then immediately rollback changes.
FLUSH_TRUE - Static variable in interface org.apache.openjpa.kernel.QueryFlushModes
Constant denoting that queries should flush data to the database automatically whenever OpenJPA determines that relevant modifications have been made and IgnoreCache is false.
FLUSH_WITH_CONNECTION - Static variable in interface org.apache.openjpa.kernel.QueryFlushModes
Constant denoting that queries should flush data to the database automatically when OpenJPA determines that relevant modifications have been made and the current context already has a dedicated connection.
flushAllRows(Row) - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy.CustomUpdate
 
flushAllRows(Row) - Method in interface org.apache.openjpa.jdbc.sql.RowManager
Flush the logical row.
flushAllRows(Row) - Method in class org.apache.openjpa.jdbc.sql.RowManagerImpl
 
flushBeforeQueries - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
flushQuery - Variable in class org.apache.openjpa.kernel.FetchConfigurationImpl.ConfigurationState
 
flushSecondaryRow(Row) - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy.CustomUpdate
 
flushSecondaryRow(Row) - Method in interface org.apache.openjpa.jdbc.sql.RowManager
Flush the secondary row; after flushing the row is available for reuse.
flushSecondaryRow(Row) - Method in class org.apache.openjpa.jdbc.sql.RowManagerImpl
 
FlushTransactionListener - Interface in org.apache.openjpa.event
Notified on transaction flush.
FORCE_LOAD_ALL - Static variable in interface org.apache.openjpa.kernel.StoreManager
 
FORCE_LOAD_DFG - Static variable in interface org.apache.openjpa.kernel.StoreManager
 
FORCE_LOAD_NONE - Static variable in interface org.apache.openjpa.kernel.StoreManager
 
FORCE_LOAD_REFRESH - Static variable in interface org.apache.openjpa.kernel.StoreManager
 
FORCE_OUTER - Static variable in interface org.apache.openjpa.jdbc.kernel.exps.Val
Initialization flag indicating to force an outer join into any relation path.
ForeignKey - Class in org.apache.openjpa.jdbc.schema
Represents a database foreign key; may be a logical key with no database representation.
ForeignKey() - Constructor for class org.apache.openjpa.jdbc.schema.ForeignKey
Default constructor.
ForeignKey(String, Table) - Constructor for class org.apache.openjpa.jdbc.schema.ForeignKey
Constructor.
ForeignKey - Annotation Type in org.apache.openjpa.persistence.jdbc
Foreign key definition.
ForeignKeyAction - Enum in org.apache.openjpa.persistence.jdbc
Foreign key actions.
foreignKeys - Variable in class org.apache.openjpa.jdbc.meta.MappingTool.Flags
 
foreignKeys - Variable in class org.apache.openjpa.jdbc.schema.SchemaTool.Flags
 
format - Variable in class org.apache.openjpa.enhance.ApplicationIdTool.Flags
 
format - Variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool.Flags
 
formatMessage(short, String, Throwable) - Method in class org.apache.openjpa.lib.log.LogFactoryImpl.LogImpl
Convert message into a string ready to be written to the log.
FormatPreservingProperties - Class in org.apache.openjpa.lib.util
A specialization of Properties that stores its contents in the same order and with the same formatting as was used to read the contents from an input stream.
FormatPreservingProperties() - Constructor for class org.apache.openjpa.lib.util.FormatPreservingProperties
 
FormatPreservingProperties(Properties) - Constructor for class org.apache.openjpa.lib.util.FormatPreservingProperties
 
FormatPreservingProperties.DuplicateKeyException - Exception in org.apache.openjpa.lib.util
 
FormatPreservingProperties.DuplicateKeyException(String, Object, String) - Constructor for exception org.apache.openjpa.lib.util.FormatPreservingProperties.DuplicateKeyException
 
forPackage(Class) - Static method in class org.apache.openjpa.lib.util.Localizer
Return a Localizer instance that will access the properties file in the package of the given class using the system default locale.
forPackage(Class, Locale) - Static method in class org.apache.openjpa.lib.util.Localizer
Return a Localizer instance that will access the properties file in the package of the given class using the given locale.
forType(int) - Method in class org.apache.openjpa.enhance.DynamicStorageGenerator
Return the proper type for the given JavaTypes constant.
forUpdateClause - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
FoxProDictionary - Class in org.apache.openjpa.jdbc.sql
Dictionary for Visual FoxPro via DataDirect SequeLink and DataDirect ODBC FoxPro driver.
FoxProDictionary() - Constructor for class org.apache.openjpa.jdbc.sql.FoxProDictionary
 
free() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager.RefCountConnection
 
free() - Method in class org.apache.openjpa.kernel.BrokerImpl
Free the resources used by this persistence manager.
FROM_SELECT_ALIAS - Static variable in interface org.apache.openjpa.jdbc.sql.Select
The alias to use for the from select, if any.
fromOpenJPAObjectId(Object) - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
Translate from a OpenJPA identity object to a Persistence one.
fromOpenJPAObjectIdClass(Class) - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
Translate from a OpenJPA identity class to a native one.
fromPKValues(Object[], ClassMetaData) - Static method in class org.apache.openjpa.util.ApplicationIds
Return a new object id constructed from the given primary key values.
fromProperties(Map) - Method in interface org.apache.openjpa.lib.conf.Configuration
Set this Configuration via the given map.
fromProperties(Map) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
fromUserProperties(Map) - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
Load the given user-supplied map of properties into this persistence unit.
FullClassStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Mapping for when the class maps all fields to its own table.
FullClassStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.FullClassStrategy
 
fullClone(int) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
fullClone(int) - Method in interface org.apache.openjpa.jdbc.sql.Select
Return a SELECT that is a complete clone of this one.
fullClone(int) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 

G

GENERAL - Static variable in interface org.apache.openjpa.util.ExceptionInfo
 
GeneralException - Exception in org.apache.openjpa.util
General exception type.
GeneralException() - Constructor for exception org.apache.openjpa.util.GeneralException
 
GeneralException(String) - Constructor for exception org.apache.openjpa.util.GeneralException
 
GeneralException(Localizer.Message) - Constructor for exception org.apache.openjpa.util.GeneralException
 
GeneralException(Throwable) - Constructor for exception org.apache.openjpa.util.GeneralException
 
GeneralException(Localizer.Message, Throwable) - Constructor for exception org.apache.openjpa.util.GeneralException
 
generateClass(String, Class) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Generate a new class with the given name.
generateCode() - Method in class org.apache.openjpa.enhance.CodeGenerator
Writes the generated code to the proper directory.
generateFieldValue(StoreContext, FieldMetaData) - Static method in class org.apache.openjpa.util.ImplHelper
Generate a value for the given metadata, or return null.
generateForeignKeys(String, String[]) - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Generate foreign key information for the given schema.
generateForeignKeys(String, String, Connection, DatabaseMetaData) - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Generates table foreign keys.
generateIdentityValue(StoreContext, ClassMetaData, int) - Static method in class org.apache.openjpa.util.ImplHelper
Generate a value for the given metadata, or return null.
generateIndexes(String, String[]) - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Generate index information for the given schema.
generateIndexes(String, String, Connection, DatabaseMetaData) - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Generates table indexes.
generatePCData(Object, ClassMetaData) - Method in class org.apache.openjpa.enhance.PCDataGenerator
Return a PCDataGenerator.DynamicPCData instance for the given oid and metadata.
generatePrimaryKeys(String, String[]) - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Generate primary key information for the given schema.
generatePrimaryKeys(String, String, Connection, DatabaseMetaData) - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Generates table primary keys.
generateSchema(String, String[]) - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Add a fully-constructed Schema matching the given database schema to the current group.
generateSchemas() - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Generate all schemas set in the configuration.
generateSchemas(String[]) - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Generate the schemas and/or tables named in the given strings.
generateSequences(String, String, Connection, DatabaseMetaData) - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Adds all sequences matching the given name pattern to the schema.
generateSQL(DBDictionary) - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
 
generateSQL(DBDictionary) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
Generate the SQL for this row; the result of this method is cached.
generateSQL(DBDictionary) - Method in class org.apache.openjpa.jdbc.sql.SecondaryRow
 
generateStorage(int[], Object) - Method in class org.apache.openjpa.enhance.DynamicStorageGenerator
Generate a generic DynamicStorage instance with the given array of JavaTypes constants and the given object as the user key for generation.
generateTables(String, String, Connection, DatabaseMetaData) - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Adds all tables matching the given name pattern to the schema.
Generator - Interface in org.apache.openjpa.persistence
Represents a store sequence.
GeneratorImpl - Class in org.apache.openjpa.persistence
Represents a store sequence.
GeneratorImpl(Seq, String, StoreContext, ClassMetaData) - Constructor for class org.apache.openjpa.persistence.GeneratorImpl
Constructor; supply delegate.
GenericConfigurable - Interface in org.apache.openjpa.lib.conf
Implementations of this interface may perform additional generic configuration with any key-value pairs that cannot be set into the object via the normal Options.setInto(java.lang.Object) means.
GenericResultObjectProvider - Class in org.apache.openjpa.jdbc.kernel
Object provider implementation wrapped around a generic Result.
GenericResultObjectProvider(Class, JDBCStore, JDBCFetchConfiguration, Result) - Constructor for class org.apache.openjpa.jdbc.kernel.GenericResultObjectProvider
Constructor.
GenericResultObjectProvider(ClassMapping, JDBCStore, JDBCFetchConfiguration, Result) - Constructor for class org.apache.openjpa.jdbc.kernel.GenericResultObjectProvider
Constructor.
get(ConfigurationProvider) - Static method in class org.apache.openjpa.conf.BrokerFactoryValue
Extract the value of this property if set in the given provider.
get(Object) - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
get(QueryKey) - Method in class org.apache.openjpa.datacache.AbstractQueryCache
 
get(Object) - Method in interface org.apache.openjpa.datacache.DataCache
Return the cached object for the given oid.
get(Object) - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
get(QueryKey) - Method in class org.apache.openjpa.datacache.DelegatingQueryCache
 
get(QueryKey) - Method in interface org.apache.openjpa.datacache.QueryCache
Return a list of oids for the given query key.
get(int) - Method in class org.apache.openjpa.datacache.QueryCacheStoreQuery.CachedList
 
get(Table, Table, boolean) - Method in interface org.apache.openjpa.jdbc.meta.MappingInfo.ForeignKeyDefaults
Return a default foreign key for the given tables, or null to create a logical foreign key only.
get(Schema) - Method in interface org.apache.openjpa.jdbc.meta.MappingInfo.TableDefaults
Return the default table name.
get(int) - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
get(FieldMetaData, boolean) - Method in interface org.apache.openjpa.kernel.exps.Path
Traverse into the given field of the current object, and update the current object to that field value.
get(int) - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
get() - Method in class org.apache.openjpa.lib.conf.BooleanValue
The internal value.
get() - Method in class org.apache.openjpa.lib.conf.DoubleValue
The internal value.
get() - Method in class org.apache.openjpa.lib.conf.FileValue
The internal value.
get() - Method in class org.apache.openjpa.lib.conf.IntValue
The internal value.
get() - Method in class org.apache.openjpa.lib.conf.ObjectValue
The internal value.
get() - Method in class org.apache.openjpa.lib.conf.StringListValue
The internal value.
get() - Method in class org.apache.openjpa.lib.conf.StringValue
The internal value.
get(int) - Method in class org.apache.openjpa.lib.rop.AbstractNonSequentialResultList
 
get(int) - Method in class org.apache.openjpa.lib.rop.AbstractSequentialResultList
 
get(int) - Method in class org.apache.openjpa.lib.rop.LazyForwardResultList
 
get(int) - Method in class org.apache.openjpa.lib.rop.ListResultList
 
get(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
Returns the value to which the specified key is mapped in this identity hash map, or null if the map contains no mapping for this key.
get(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
Returns the value to which this HashMap maps the specified key.
get(int) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
get(String) - Method in class org.apache.openjpa.lib.util.Localizer
Return the localized string matching the given key.
get(String, Object) - Method in class org.apache.openjpa.lib.util.Localizer
Return the localized string matching the given key.
get(String, Object, Object) - Method in class org.apache.openjpa.lib.util.Localizer
Return the localized string for the given key.
get(String, Object, Object, Object) - Method in class org.apache.openjpa.lib.util.Localizer
Return the localized string for the given key.
get(String, Object[]) - Method in class org.apache.openjpa.lib.util.Localizer
Return the localized string matching the given key.
get(Object) - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
get(Object, FieldMetaData) - Static method in class org.apache.openjpa.util.ApplicationIds
Return the given primary key field value from the given oid.
get(Object) - Method in class org.apache.openjpa.util.CacheMap
 
getAccessPath() - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
Return the recorded query access path.
getAccessPathMetaDatas(StoreQuery) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery.AbstractExecutor
 
getAccessPathMetaDatas() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getAccessPathMetaDatas() - Method in interface org.apache.openjpa.kernel.QueryContext
Return the classes that affect this query.
getAccessPathMetaDatas() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getAccessPathMetaDatas(StoreQuery) - Method in interface org.apache.openjpa.kernel.StoreQuery.Executor
Return an array of all persistent classes used in this query, or empty array if unknown.
getAccessType(ClassMetaData) - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
Return the access type of the given metadata.
getAccessType() - Method in class org.apache.openjpa.meta.ClassMetaData
The access type used by this class.
getAccessType(ClassMetaData) - Method in class org.apache.openjpa.persistence.PersistenceMetaDataDefaults
 
getAccessUnloaded() - Method in class org.apache.openjpa.conf.DetachOptions
Whether to allow access to unloaded detached fields.
getAction() - Method in class org.apache.openjpa.jdbc.meta.MappingTool
The action supplied on construction.
getAction(String) - Static method in class org.apache.openjpa.jdbc.schema.ForeignKey
Return the foreign key action constant for the given action name.
getAction() - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
The action supplied on construction.
getAction() - Method in interface org.apache.openjpa.jdbc.sql.Row
Return the action for this row.
getAction() - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
getAction() - Method in class org.apache.openjpa.kernel.InverseManager
Return the action constant to use during relationship checking.
getAction() - Method in class org.apache.openjpa.meta.MetaDataTool
The action supplied on construction.
getActionName(int) - Static method in class org.apache.openjpa.jdbc.schema.ForeignKey
Return the foreign key action name for the given action constant.
getAddColumnSQL(Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return a series of SQL statements to add the given column to its table.
getAddColumnSQL(Column) - Method in class org.apache.openjpa.jdbc.sql.HSQLDictionary
 
getAddDefaultConstructor() - Method in class org.apache.openjpa.enhance.PCEnhancer
A boolean indicating whether the enhancer should add a no-args constructor if one is not already present in the class.
getAdded() - Method in class org.apache.openjpa.util.AbstractChangeTracker
 
getAdded() - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
getAdded() - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
getAdded() - Method in interface org.apache.openjpa.util.ChangeTracker
Return the collection of values that need to be added to the managed container.
getAddForeignKeySQL(ForeignKey) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return a series of SQL statements to add the given foreign key to its table.
getAddForeignKeySQL(ForeignKey) - Method in class org.apache.openjpa.jdbc.sql.InformixDictionary
 
getAddForeignKeySQL(ForeignKey) - Method in class org.apache.openjpa.jdbc.sql.SybaseDictionary
 
getAdditionalBeanInfo() - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
getAddNullIndicator() - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Whether to add a synthetic null indicator column to embedded mappings by default.
getAddPrimaryKeySQL(PrimaryKey) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return a series of SQL statements to add the given primary key to its table.
getAddPrimaryKeySQL(PrimaryKey) - Method in class org.apache.openjpa.jdbc.sql.HSQLDictionary
 
getAddPrimaryKeySQL(PrimaryKey) - Method in class org.apache.openjpa.jdbc.sql.InformixDictionary
 
getAddPrimaryKeySQL(PrimaryKey) - Method in class org.apache.openjpa.jdbc.sql.MySQLDictionary
 
getAddWhitespaceAfterDelimiter() - Method in class org.apache.openjpa.lib.util.FormatPreservingProperties
If set to true, this properties object will add a space after the delimiter character(if the delimiter is not the space character).
getAfterSection() - Method in class org.apache.openjpa.lib.util.CodeFormat
Return {#getLinesBetweenSections} + 1 new line characters.
getAggregateListener(String) - Method in class org.apache.openjpa.datacache.QueryCacheStoreQuery
 
getAggregateListener(String) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery
 
getAggregateListener(String) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getAggregateListener(String) - Method in interface org.apache.openjpa.kernel.exps.Resolver
Return the function listener for the given tag, or null if none.
getAggregateListener(String) - Method in interface org.apache.openjpa.kernel.QueryContext
Return the filter listener for the given tag, or null.
getAggregateListener(String) - Method in class org.apache.openjpa.kernel.QueryImpl
 
getAggregateListener(String) - Method in interface org.apache.openjpa.kernel.StoreQuery
Return the standard filter listener for the given tag, or null.
getAggregateListenerInstances() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Return the query function listeners.
getAggregateListenerInstances() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getAggregateListeners() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
A comma-separted list of the plugin strings of the query AggregateListeners to use.
getAggregateListeners() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getAggregateListeners() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getAggregateListeners() - Method in interface org.apache.openjpa.kernel.QueryContext
The set of aggregate listeners.
getAggregateListeners() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getAlias() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
getAlias() - Method in class org.apache.openjpa.jdbc.meta.Discriminator
 
getAlias() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
getAlias() - Method in interface org.apache.openjpa.jdbc.meta.Strategy
Return the alias of this strategy.
getAlias() - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractStrategy
 
getAlias() - Method in class org.apache.openjpa.jdbc.meta.strats.ClassNameDiscriminatorStrategy
 
getAlias() - Method in class org.apache.openjpa.jdbc.meta.strats.FlatClassStrategy
 
getAlias() - Method in class org.apache.openjpa.jdbc.meta.strats.FullClassStrategy
 
getAlias() - Method in class org.apache.openjpa.jdbc.meta.strats.NoneClassStrategy
 
getAlias() - Method in class org.apache.openjpa.jdbc.meta.strats.NoneDiscriminatorStrategy
 
getAlias() - Method in class org.apache.openjpa.jdbc.meta.strats.NoneFieldStrategy
 
getAlias() - Method in class org.apache.openjpa.jdbc.meta.strats.NoneVersionStrategy
 
getAlias() - Method in class org.apache.openjpa.jdbc.meta.strats.NumberVersionStrategy
 
getAlias() - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy
 
getAlias() - Method in class org.apache.openjpa.jdbc.meta.strats.SubclassJoinDiscriminatorStrategy
 
getAlias() - Method in class org.apache.openjpa.jdbc.meta.strats.TimestampVersionStrategy
 
getAlias() - Method in class org.apache.openjpa.jdbc.meta.strats.ValueMapDiscriminatorStrategy
 
getAlias() - Method in class org.apache.openjpa.jdbc.meta.strats.VerticalClassStrategy
 
getAlias() - Method in class org.apache.openjpa.jdbc.meta.Version
 
getAlias(StoreQuery) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery.AbstractExecutor
 
getAlias() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getAlias() - Method in interface org.apache.openjpa.kernel.QueryContext
If this query is not a projection but places candidate results into a result class under an alias, return that alias.
getAlias() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getAlias(StoreQuery) - Method in interface org.apache.openjpa.kernel.StoreQuery.Executor
If this is not a projection but the candidate results are placed into a result class with an alias, return that alias.
getAlias1() - Method in class org.apache.openjpa.jdbc.sql.Join
 
getAlias2() - Method in class org.apache.openjpa.jdbc.sql.Join
 
getAliases() - Method in class org.apache.openjpa.lib.conf.Value
Aliases for the value in the form key1, value1, key2, value2, ...
getAllocate() - Method in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
 
getAllocate() - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
Return the number of sequences to allocate for each update of the sequence table.
getAllocate() - Method in class org.apache.openjpa.jdbc.schema.Sequence
The sequence's cache size.
getAllocate() - Method in class org.apache.openjpa.meta.SequenceMetaData
Sequence values to allocate, or -1 for default.
getAllowDuplicates() - Method in class org.apache.openjpa.lib.util.FormatPreservingProperties
If set to true, duplicate properties are allowed, and the last property setting in the input will overwrite any previous settings.
getAllowsMultipleMethodsForSameCallback() - Method in class org.apache.openjpa.persistence.PersistenceMetaDataDefaults
Flags if multiple methods of the same class can handle the same callback event.
getAllRowDeletes() - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy.CustomUpdate
 
getAllRowDeletes() - Method in class org.apache.openjpa.jdbc.sql.RowManagerImpl
Return any 'all row' deletes.
getAllRows(Table, int) - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy.CustomUpdate
 
getAllRows(Table, int) - Method in interface org.apache.openjpa.jdbc.sql.RowManager
Return a logical row representing an update that should be made to all rows of the given table.
getAllRows(Table, int) - Method in class org.apache.openjpa.jdbc.sql.RowManagerImpl
 
getAllRowUpdates() - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy.CustomUpdate
 
getAllRowUpdates() - Method in class org.apache.openjpa.jdbc.sql.RowManagerImpl
Return any 'all row' updates.
getAnnotationParser() - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
Return metadata parser, creating it if it does not already exist.
getAnnotationParser() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
The annotation parser.
getArray(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getArray(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getArray(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getArray(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getArray(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getArray(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id; may not be supported by results that are not backed by a SQL result set.
getArray(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column; may not be supported by results that are not backed by a SQL result set.
getArray(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getArray(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getArray(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getArray(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getArrayInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getArrayInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getAscending(StoreQuery) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery.AbstractExecutor
 
getAscending(StoreQuery) - Method in interface org.apache.openjpa.kernel.StoreQuery.Executor
Return the ordering direction for all ordering clauses, or empty array if none.
getAsciiStream(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getAsciiStream(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getAsciiStream(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getAsciiStream(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getAsciiStream(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getAsciiStream(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id; may not be supported by results that are not backed by a SQL result set.
getAsciiStream(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column; may not be supported by results that are not backed by a SQL result set.
getAsciiStream(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getAsciiStream(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getAsciiStreamInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getAsciiStreamInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getAssertAllowedType() - Method in class org.apache.openjpa.util.ProxyManagerImpl
Whether to perform runtime checks to ensure that all elements added to collection and map proxies are the proper element/key/value type as defined by the metadata.
getAssociatedEvent() - Method in class org.apache.openjpa.lib.jdbc.JDBCEvent
Return the associated JDBCEvent for this event.
getAttributes(String, String, String, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getAttributes() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
The current attributes.
getAutoAssignedColumns() - Method in class org.apache.openjpa.jdbc.schema.Table
Return this table's auto-assigned columns.
getAutoClear() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Whether instances clear their state when entering a transaction.
getAutoClear() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getAutoClear() - Method in interface org.apache.openjpa.kernel.Broker
Whether objects clear when entering transactions.
getAutoClear() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getAutoClear() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getAutoClear() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getAutoClear() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether to clear state when entering a transaction.
getAutoClearConstant() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Return the AutoClear constant.
getAutoClearConstant() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getAutoCommit() - Method in class org.apache.openjpa.lib.jdbc.ConfiguringConnectionDecorator
Whether auto commit should be on.
getAutoCommit() - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
getAutoDetach() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
A comma-separated list of events which trigger auto-detachment in place of managed states.
getAutoDetach() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getAutoDetach() - Method in interface org.apache.openjpa.kernel.Broker
Bit flags marked in AutoDetach which indicate when persistent managed objects should be automatically detached in-place.
getAutoDetach() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getAutoDetach() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getAutoDetach() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getAutoDetach() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Bit flags marked in AutoDetach which indicate when persistent managed objects should be automatically detached in-place.
getAutoDetachConstant() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The AutoDetach flags.
getAutoDetachConstant() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getAutoDistinct() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
getAutoDistinct() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getAutoDistinct() - Method in interface org.apache.openjpa.jdbc.sql.SelectExecutor
Whether to automatically make results distinct when relational joins would otherwise introduce duplicates.
getAutoDistinct() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getAutoOff() - Method in class org.apache.openjpa.util.AbstractChangeTracker
Whether to automatically stop tracking when the number of changes exceeds the container size.
getAuxiliaryEnhancers() - Method in class org.apache.openjpa.enhance.PCEnhancer
Gets the auxiliary enhancers registered as services.
getBackingMember(FieldMetaData) - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
 
getBackingMember() - Method in class org.apache.openjpa.meta.FieldMetaData
Return the backing member supplied in FieldMetaData.backingMember(java.lang.reflect.Member).
getBackingMember(FieldMetaData) - Method in interface org.apache.openjpa.meta.MetaDataDefaults
Return the backing member for the given field metadata.
getBackingMember(FieldMetaData) - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
getBaseClassStrategy() - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default base class strategy alias.
getBaseMapping() - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getBaseMapping() - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getBaseMapping() - Method in interface org.apache.openjpa.jdbc.sql.Result
If this is the result of a UNION used to select a hierarchy of mappings, the base mapping represented by the current row.
getBeanDescriptor() - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
getBestRowIdentifier(String, String, String, int, boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getBigDecimal(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getBigDecimal(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getBigDecimal(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getBigDecimal(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getBigDecimal(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getBigDecimal(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id.
getBigDecimal(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column.
getBigDecimal(int, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getBigDecimal(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getBigDecimal(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getBigDecimal(int, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getBigDecimal(String, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getBigDecimal(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getBigDecimal(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getBigDecimalInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getBigDecimalInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getBigInteger(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getBigInteger(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getBigInteger(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getBigInteger(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getBigInteger(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getBigInteger(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id.
getBigInteger(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column.
getBigIntegerInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getBigIntegerInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getBinaryStream(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getBinaryStream(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getBinaryStream(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getBinaryStream(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getBinaryStream(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getBinaryStream(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id; may not be supported by results that are not backed by a SQL result set.
getBinaryStream(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column; may not be supported by results that are not backed by a SQL result set.
getBinaryStream(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getBinaryStream(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getBinaryStreamInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getBinaryStreamInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getBlob(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getBlob(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getBlob(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getBlob(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getBlob(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getBlob(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id; may not be supported by results that are not backed by a SQL result set.
getBlob(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column; may not be supported by results that are not backed by a SQL result set.
getBlob(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getBlob(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getBlob(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getBlob(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getBlobAsObject() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Whether to reverse-map blob columns as containing serialized Java objects, rather than the default of using a byte[] field.
getBlobInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getBlobInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getBlobObject(ResultSet, int, JDBCStore) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getBlobObject(ResultSet, int, JDBCStore) - Method in class org.apache.openjpa.jdbc.sql.MySQLDictionary
 
getBoolean(int) - Method in interface org.apache.openjpa.enhance.DynamicStorage
Get the boolean at the given index.
getBoolean(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getBoolean(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getBoolean(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getBoolean(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getBoolean(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getBoolean(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id.
getBoolean(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column.
getBoolean(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getBoolean(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getBoolean(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getBoolean(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getBooleanExtension(String) - Method in class org.apache.openjpa.meta.Extensions
Get the value as a boolean.
getBooleanExtension(String, String) - Method in class org.apache.openjpa.meta.Extensions
Get the value as a boolean.
getBooleanInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getBooleanInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getBooleanProperty(String, String, boolean) - Method in class org.apache.openjpa.lib.util.Options
Specialization of Options.getBooleanProperty(java.lang.String, java.lang.String, boolean) to allow a value to appear under either of two keys; useful for short and long versions of command-line flags.
getBooleanProperty(String) - Method in class org.apache.openjpa.lib.util.TypedProperties
Return the property under the given key as a boolean, or false if it does not exist and has no set default.
getBooleanProperty(String, boolean) - Method in class org.apache.openjpa.lib.util.TypedProperties
Return the property under the given key as a boolean, or the given default if it does not exist.
getBraceAtSameTabLevel() - Method in class org.apache.openjpa.lib.util.CodeFormat
Whether to place braces at the same tab level as the code within the block.
getBraceOnSameLine() - Method in class org.apache.openjpa.lib.util.CodeFormat
Whether to place opening braces on the same line as the block declaration, or on the next line.
getBroker() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getBroker() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getBroker() - Method in class org.apache.openjpa.kernel.DelegatingExtent
 
getBroker() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getBroker() - Method in interface org.apache.openjpa.kernel.Extent
The broker that generated the extent.
getBroker() - Method in class org.apache.openjpa.kernel.ExtentImpl
 
getBroker() - Method in class org.apache.openjpa.kernel.OpenJPASavepoint
Return the Broker associated with this savepoint.
getBroker() - Method in interface org.apache.openjpa.kernel.Query
The broker that generated this query.
getBroker() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getBroker() - Method in interface org.apache.openjpa.kernel.StoreContext
Return the broker for this context, if possible.
getBroker() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
Broker delegate.
getBrokerFactory() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The BrokerFactory class to use.
getBrokerFactory() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getBrokerFactory() - Static method in class org.apache.openjpa.kernel.Bootstrap
Return a pooled factory for the default configuration.
getBrokerFactory(ConfigurationProvider, ClassLoader) - Static method in class org.apache.openjpa.kernel.Bootstrap
Return a pooled factory for the given configuration.
getBrokerFactory() - Method in interface org.apache.openjpa.kernel.Broker
Return the factory that produced this broker.
getBrokerFactory() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getBrokerFactory() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getBrokerFactory() - Method in class org.apache.openjpa.persistence.EntityManagerFactoryImpl
Delegate.
getBrokerImpl() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The plugin string of the BrokerImpl extension to create.
getBrokerImpl() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getBuffer() - Method in class org.apache.openjpa.lib.util.CodeFormat
Return the internal code buffer.
getByte(int) - Method in interface org.apache.openjpa.enhance.DynamicStorage
Get the byte at the given index.
getByte(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getByte(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getByte(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getByte(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getByte(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getByte(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.PostgresDictionary
 
getByte(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id.
getByte(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column.
getByte(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getByte(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getByte(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getByte(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getBytecode() - Method in class org.apache.openjpa.enhance.PCEnhancer
Return the bytecode representation of the class being manipulated.
getBytecodeWriter() - Method in class org.apache.openjpa.enhance.PCEnhancer
Return the current BytecodeWriter to write to or null if none.
getByteInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getByteInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getBytes(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getBytes(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getBytes(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getBytes(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getBytes(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getBytes(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id; may not be supported by results that are not backed by a SQL result set.
getBytes(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column; may not be supported by results that are not backed by a SQL result set.
getBytes(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getBytes(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getBytes(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getBytes(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getBytesInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getBytesInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getCache() - Method in class org.apache.openjpa.datacache.QueryCacheStoreQuery
Return the QueryCache that this object is associated with.
getCachedMetaData(Class) - Method in class org.apache.openjpa.meta.MetaDataRepository
Return the cached metadata for the given class, without any resolution.
getCachedQueryMetaData(Class, String) - Method in class org.apache.openjpa.meta.MetaDataRepository
Return the cached query metadata for the given name.
getCachedQueryResultMapping(Class, String) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Return the cached query result mapping with the given name, or null if none.
getCachedSequenceMetaData(String) - Method in class org.apache.openjpa.meta.MetaDataRepository
Return the cached a sequence metadata for the given name.
getCacheMap() - Method in class org.apache.openjpa.datacache.ConcurrentDataCache
Returns the underlying CacheMap that this cache is using.
getCacheMap() - Method in class org.apache.openjpa.datacache.ConcurrentQueryCache
Returns the underlying CacheMap that this cache is using.
getCacheSize() - Method in class org.apache.openjpa.datacache.ConcurrentDataCache
Returns the maximum number of unpinned objects to keep hard references to.
getCacheSize() - Method in class org.apache.openjpa.datacache.ConcurrentQueryCache
Returns the maximum number of unpinned objects to keep hard references to.
getCacheSize() - Method in class org.apache.openjpa.util.CacheMap
The maximum number of hard references to maintain, or -1 for no limit.
getCalendar(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getCalendar(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getCalendar(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getCalendar(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getCalendar(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getCalendar(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id.
getCalendar(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column.
getCalendarInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getCalendarInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getCallbackMethod() - Method in class org.apache.openjpa.event.MethodLifecycleCallbacks
The callback method.
getCallbackMode() - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
 
getCallbackMode() - Method in interface org.apache.openjpa.meta.MetaDataDefaults
What to do on lifecycle callback exceptions.
getCallbackMode() - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
getCallbacks(int) - Method in class org.apache.openjpa.meta.LifecycleMetaData
Return all callbacks for the given event type, including superclass callbacks if appropriate.
getCallbacksBeforeListeners(int) - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
 
getCallbacksBeforeListeners(int) - Method in interface org.apache.openjpa.meta.MetaDataDefaults
If callbacks are fired before listeners for the given event type.
getCallbacksBeforeListeners(int) - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
getCandidateAlias() - Method in interface org.apache.openjpa.kernel.exps.Subquery
Return the candidate alias for this subquery.
getCandidateCollection() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getCandidateCollection() - Method in interface org.apache.openjpa.kernel.QueryContext
Return the candidate collection, or null if an extent was specified instead of a collection.
getCandidateCollection() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getCandidateCollection() - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Return the candidate collection, or null if an extent was specified instead of a collection.
getCandidateCollection() - Method in class org.apache.openjpa.persistence.QueryImpl
 
getCandidateExtent() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getCandidateExtent() - Method in interface org.apache.openjpa.kernel.Query
Return the candidate extent, or null if a collection was specified instead of an extent.
getCandidateExtent() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getCandidateType() - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping.PCResult
The result candidate class.
getCandidateType() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getCandidateType() - Method in interface org.apache.openjpa.kernel.QueryContext
Return the class of the objects that this query will return, or null if this information is not available / not relevant.
getCandidateType() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getCandidateType() - Method in class org.apache.openjpa.meta.QueryMetaData
The query candidate class, or null if none.
getCandidateTypeMapping() - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping.PCResult
Candidate mapping.
getCandidateTypeName() - Method in class org.apache.openjpa.datacache.QueryKey
Returns the candidate class name for this query.
getCascadeAttach() - Method in class org.apache.openjpa.meta.FieldMetaData
 
getCascadeAttach() - Method in interface org.apache.openjpa.meta.ValueMetaData
Cascade behavior for attach operation.
getCascadeAttach() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
getCascadeDelete() - Method in class org.apache.openjpa.meta.FieldMetaData
 
getCascadeDelete() - Method in interface org.apache.openjpa.meta.ValueMetaData
Cascade behavior for delete operation.
getCascadeDelete() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
getCascadePersist() - Method in class org.apache.openjpa.meta.FieldMetaData
 
getCascadePersist() - Method in interface org.apache.openjpa.meta.ValueMetaData
Cascade behavior for persist operation.
getCascadePersist() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
getCascadeRefresh() - Method in class org.apache.openjpa.meta.FieldMetaData
 
getCascadeRefresh() - Method in interface org.apache.openjpa.meta.ValueMetaData
Cascade behavior for refresh operation.
getCascadeRefresh() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
getCatalog() - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
getCatalogNameForMetadata(String) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Returns the catalog name that will be used for obtaining information from DatabaseMetaData.
getCatalogs() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getCatalogSeparator() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getCatalogTerm() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getCause(Throwable) - Static method in class org.apache.openjpa.lib.util.JavaVersions
Return the cause of the given throwable.
getCause() - Method in exception org.apache.openjpa.persistence.ArgumentException
 
getCause() - Method in exception org.apache.openjpa.persistence.EntityExistsException
 
getCause() - Method in exception org.apache.openjpa.persistence.EntityNotFoundException
 
getCause() - Method in exception org.apache.openjpa.persistence.InvalidStateException
 
getCause() - Method in exception org.apache.openjpa.persistence.NonUniqueResultException
 
getCause() - Method in exception org.apache.openjpa.persistence.NoResultException
 
getCause() - Method in exception org.apache.openjpa.persistence.OptimisticLockException
 
getCause() - Method in exception org.apache.openjpa.persistence.PersistenceException
 
getCause() - Method in exception org.apache.openjpa.persistence.RollbackException
 
getCause() - Method in exception org.apache.openjpa.persistence.TransactionRequiredException
 
getCause() - Method in interface org.apache.openjpa.util.ExceptionInfo
Returns the first Throwable from ExceptionInfo.getNestedThrowables() in order to conform to Throwable.getCause() in Java 1.4+.
getCause() - Method in exception org.apache.openjpa.util.OpenJPAException
Returns the first Throwable from OpenJPAException.getNestedThrowables() in order to conform to Throwable.getCause() in Java 1.4+.
getChanged() - Method in class org.apache.openjpa.util.AbstractChangeTracker
 
getChanged() - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
getChanged() - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
getChanged() - Method in interface org.apache.openjpa.util.ChangeTracker
Return the set of elements that have changed.
getChangeTracker() - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
getChangeTracker() - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
getChangeTracker() - Method in interface org.apache.openjpa.util.Proxy
Return the change tracker for this proxy, or null if none.
getChangeTracker() - Method in class org.apache.openjpa.util.ProxyArrayList
 
getChangeTracker() - Method in class org.apache.openjpa.util.ProxyGregorianCalendar
 
getChangeTracker() - Method in class org.apache.openjpa.util.ProxyHashMap
 
getChangeTracker() - Method in class org.apache.openjpa.util.ProxyHashSet
 
getChangeTracker() - Method in class org.apache.openjpa.util.ProxyHashtable
 
getChangeTracker() - Method in class org.apache.openjpa.util.ProxyLinkedList
 
getChangeTracker() - Method in class org.apache.openjpa.util.ProxyProperties
 
getChangeTracker() - Method in class org.apache.openjpa.util.ProxySQLDate
 
getChangeTracker() - Method in class org.apache.openjpa.util.ProxyTime
 
getChangeTracker() - Method in class org.apache.openjpa.util.ProxyTimestamp
 
getChangeTracker() - Method in class org.apache.openjpa.util.ProxyTreeMap
 
getChangeTracker() - Method in class org.apache.openjpa.util.ProxyTreeSet
 
getChangeTracker() - Method in class org.apache.openjpa.util.ProxyUtilDate
 
getChangeTracker() - Method in class org.apache.openjpa.util.ProxyVector
 
getChannel() - Method in class org.apache.openjpa.event.LogOrphanedKeyAction
The channel to log to.
getChannel() - Method in class org.apache.openjpa.lib.log.LogFactoryImpl.LogImpl
 
getChar(int) - Method in interface org.apache.openjpa.enhance.DynamicStorage
Get the char at the given index.
getChar(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getChar(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getChar(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getChar(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getChar(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getChar(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id.
getChar(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column.
getCharacterStream(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getCharacterStream(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getCharacterStream(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getCharacterStream(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getCharacterStream(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getCharacterStream(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id; may not be supported by results that are not backed by a SQL result set.
getCharacterStream(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column; may not be supported by results that are not backed by a SQL result set.
getCharacterStream(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getCharacterStream(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getCharacterStreamInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getCharacterStreamInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getCharInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getCharInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getClass(JDBCStore, ClassMapping, Result) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
 
getClass(JDBCStore, ClassMapping, Result) - Method in interface org.apache.openjpa.jdbc.meta.DiscriminatorStrategy
Return the class for the current result row.
getClass(JDBCStore, ClassMapping, Result) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractDiscriminatorStrategy
 
getClass(Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.ClassNameDiscriminatorStrategy
 
getClass(Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.InValueDiscriminatorStrategy
Convert the given discriminator value to the corresponding class.
getClass(JDBCStore, ClassMapping, Result) - Method in class org.apache.openjpa.jdbc.meta.strats.InValueDiscriminatorStrategy
 
getClass(JDBCStore, ClassMapping, Result) - Method in class org.apache.openjpa.jdbc.meta.strats.SubclassJoinDiscriminatorStrategy
 
getClass(JDBCStore, ClassMapping, Result) - Method in class org.apache.openjpa.jdbc.meta.strats.SuperclassDiscriminatorStrategy
 
getClass(Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.ValueMapDiscriminatorStrategy
 
getClassAttributeName() - Method in class org.apache.openjpa.lib.meta.CFMetaDataParser
The attribute of the class element that holds the name, or null to use the element text.
getClassAttributeName() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
getClassCode() - Method in class org.apache.openjpa.enhance.CodeGenerator
Return a code template for the given class, or null to use the standard system-generated Java code.
getClassCode(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.PropertiesReverseCustomizer
 
getClassCode(ClassMapping) - Method in interface org.apache.openjpa.jdbc.meta.ReverseCustomizer
Return a code template for the given class, or null to use the standard system-generated Java code.
getClassConditions(Select, Joins, ClassMapping, boolean) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
 
getClassConditions(Select, Joins, ClassMapping, boolean) - Method in interface org.apache.openjpa.jdbc.meta.DiscriminatorStrategy
Return SQL to limit the classes selected as much as possible to the given base class, and optionally its subclasses.
getClassConditions(Select, Joins, ClassMapping, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractDiscriminatorStrategy
 
getClassConditions(Select, Joins, ClassMapping, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.InValueDiscriminatorStrategy
 
getClassConditions(Select, Joins, ClassMapping, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.SubclassJoinDiscriminatorStrategy
 
getClassConditions(Select, Joins, ClassMapping, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.SuperclassDiscriminatorStrategy
 
getClassElementDepth() - Method in class org.apache.openjpa.lib.meta.CFMetaDataParser
The depth of the class element.
getClassElementDepth() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
getClassFile(Class) - Static method in class org.apache.openjpa.lib.util.Files
Return the class file of the given class, or null if the class is in a jar.
getClassLoader() - Method in interface org.apache.openjpa.jdbc.schema.DriverDataSource
Classloader for loading driver class, etc.
getClassLoader() - Method in class org.apache.openjpa.jdbc.schema.SimpleDriverDataSource
 
getClassLoader() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getClassLoader() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getClassLoader() - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
Returns the class loader that should be used for resolving class names (in addition to the resolver in the query).
getClassLoader() - Method in interface org.apache.openjpa.kernel.StoreContext
Return the current thread's class loader at the time this context was obtained.
getClassLoader() - Method in class org.apache.openjpa.lib.ant.AbstractTask
Return the classloader to use.
getClassLoader() - Method in class org.apache.openjpa.lib.meta.ClassArgParser
The class loader with which to load parsed classes.
getClassLoader() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Classloader to use for class name resolution.
getClassLoader(int) - Method in class org.apache.openjpa.lib.util.MultiClassLoader
Return the class loader at the given index.
getClassLoader() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getClassLoader() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return the current thread's class loader at the time this entity manager was obtained from the factory.
getClassLoader() - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
getClassLoader(Class, ClassLoader) - Method in interface org.apache.openjpa.util.ClassResolver
Return a class loader that can be used to load classes and resources.
getClassLoader(Class, ClassLoader) - Method in class org.apache.openjpa.util.ClassResolverImpl
 
getClassLoader(Class, ClassLoader) - Method in class org.apache.openjpa.util.MultiLoaderClassResolver
 
getClassLoaders() - Method in class org.apache.openjpa.lib.util.MultiClassLoader
Return an array of all contained class loaders.
getClassMapping() - Method in interface org.apache.openjpa.jdbc.kernel.exps.FilterValue
If this is a path to a persistent object, return its class mapping, else return null.
getClassMapping() - Method in class org.apache.openjpa.jdbc.meta.Discriminator
Return the owning mapping.
getClassMapping(Table) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Return the class mapping for the given table, or null if none.
getClassMapping() - Method in class org.apache.openjpa.jdbc.meta.Version
Return the owning mapping.
getClassName(Object) - Method in class org.apache.openjpa.enhance.DynamicStorageGenerator
Return a class name to use for the given user key.
getClassName(Object) - Method in class org.apache.openjpa.enhance.PCDataGenerator
 
getClassName() - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
The described class name.
getClassName(Table, String) - Method in class org.apache.openjpa.jdbc.meta.PropertiesReverseCustomizer
 
getClassName(Table, String) - Method in interface org.apache.openjpa.jdbc.meta.ReverseCustomizer
Return the fully-qualified class name to generate for the given table.
getClassName(String) - Static method in class org.apache.openjpa.lib.conf.Configurations
Return the class name from the given plugin string, or null if none.
getClassName() - Method in class org.apache.openjpa.lib.conf.PluginValue
The plugin class name.
getClassName(String) - Method in class org.apache.openjpa.lib.meta.CFMetaDataSerializer
Returns the given class name, stripping the package if it is not needed.
getClassNames() - Method in class org.apache.openjpa.lib.conf.PluginListValue
The plugin class names.
getClassResolver() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The plugin string for the ClassResolver to use for custom class loading.
getClassResolver() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getClassResolverInstance() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The ClassResolver to use.
getClassResolverInstance() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getClauseIndent() - Method in class org.apache.openjpa.lib.jdbc.SQLFormatter
 
getClientConnection() - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
Returns null.
getClientConnection() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
getClientConnection() - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
getClientConnection() - Method in interface org.apache.openjpa.kernel.StoreManager
Return a connection to the data store suitable for client use.
getClob(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getClob(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getClob(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getClob(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getClob(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getClob(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id; may not be supported by results that are not backed by a SQL result set.
getClob(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column; may not be supported by results that are not backed by a SQL result set.
getClob(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getClob(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getClob(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getClob(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getClobInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getClobInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getClobString(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getClobString(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
getCloseBrace(int) - Method in class org.apache.openjpa.lib.util.CodeFormat
Close brace string.
getCloseConnection() - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
Whether to close the backing connection when this result is closed.
getCloseOnManagedCommit() - Method in class org.apache.openjpa.conf.Compatibility
Whether to close the broker when the managed transaction commits.
getCloseParen() - Method in class org.apache.openjpa.lib.util.CodeFormat
Close parentheses string.
getClosestLevenshteinDistance(String, String[]) - Static method in class org.apache.openjpa.lib.util.StringDistance
Returns the candidate string with the closest Levenshtein distance to the given string.
getClosestLevenshteinDistance(String, Collection) - Static method in class org.apache.openjpa.lib.util.StringDistance
Returns the candidate string with the closest Levenshtein distance to the given string.
getClosestLevenshteinDistance(String, String[], int) - Static method in class org.apache.openjpa.lib.util.StringDistance
Returns the candidate string with the closest Levenshtein distance to the given string.
getClosestLevenshteinDistance(String, String[], float) - Static method in class org.apache.openjpa.lib.util.StringDistance
Returns the candidate string with the closest Levenshtein distance to the given string and using the threshold as the specified percentage of the length of the candidate string(0.0f-1.0f).
getClosestLevenshteinDistance(String, Collection, float) - Static method in class org.apache.openjpa.lib.util.StringDistance
Returns the candidate string with the closest Levenshtein distance to the given string and using the threshold as the specified percentage of the length of the candidate string(0.0f-1.0f).
getClosestLevenshteinDistance(String, Collection, int) - Static method in class org.apache.openjpa.lib.util.StringDistance
Returns the candidate string with the closest Levenshtein distance to the given string.
getCode() - Method in class org.apache.openjpa.enhance.ApplicationIdTool
Return the code generated for the application id, or null if invalid class or the ApplicationIdTool.run() method has not been called.
getCode() - Method in class org.apache.openjpa.enhance.CodeGenerator
Return the generated code, or null if CodeGenerator.generateCode() has not been called.
getCode(String, Object) - Static method in class org.apache.openjpa.meta.UpdateStrategies
Convert the given strategy name to its constant.
getCode(String, Object) - Static method in class org.apache.openjpa.meta.ValueStrategies
Convert the given strategy name to its constant.
getCodeDirectory() - Method in class org.apache.openjpa.enhance.CodeGenerator
The directory to write source to.
getCodeFormat() - Method in class org.apache.openjpa.enhance.ApplicationIdTool
The code formatter for the generated Java code.
getCodeFormat() - Method in class org.apache.openjpa.enhance.CodeGenerator
The code formatter for the generated Java code.
getCodeFormat() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
The code formatter for the generated Java code.
GetColumn - Class in org.apache.openjpa.jdbc.kernel.exps
Returns the SQL alias of the named column for use in a query.
GetColumn() - Constructor for class org.apache.openjpa.jdbc.kernel.exps.GetColumn
 
getColumn(Column) - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Return the local column joined to the given primary key column.
getColumn(String) - Method in class org.apache.openjpa.jdbc.schema.Table
Return the column with the given name, or null if none.
getColumnAlias(Column) - Method in interface org.apache.openjpa.jdbc.kernel.exps.FilterValue
Return the alias to use for the given column (this includes the table alias prefix, if any).
getColumnAlias(String, Table) - Method in interface org.apache.openjpa.jdbc.kernel.exps.FilterValue
Return the alias to use for the given column (this includes the table alias prefix, if any).
getColumnAlias(Column) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getColumnAlias(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getColumnAlias(String, Table) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getColumnAlias(String, Table, Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getColumnAlias(Column) - Method in interface org.apache.openjpa.jdbc.sql.Select
Return the alias for the given column.
getColumnAlias(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
Return the alias for the given column.
getColumnAlias(String, Table) - Method in interface org.apache.openjpa.jdbc.sql.Select
Return the alias for the given column.
getColumnAlias(String, Table, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
Return the alias for the given column.
getColumnAlias(Column) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getColumnAlias(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getColumnAlias(String, Table) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getColumnAlias(String, Table, Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getColumnIO() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
I/O information on the key columns / join key.
getColumnIO() - Method in class org.apache.openjpa.jdbc.meta.Discriminator
I/O information on the discriminator columns.
getColumnIO() - Method in interface org.apache.openjpa.jdbc.meta.Embeddable
Return column I/O information for this mapping.
getColumnIO() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
getColumnIO() - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
I/O for the columns created by the last call to MappingInfo.createColumns(org.apache.openjpa.meta.MetaDataContext, java.lang.String, org.apache.openjpa.jdbc.schema.Column[], org.apache.openjpa.jdbc.schema.Table, boolean), or for the foreign key created by the last call to MappingInfo.createForeignKey(org.apache.openjpa.meta.MetaDataContext, java.lang.String, java.util.List, org.apache.openjpa.jdbc.meta.MappingInfo.ForeignKeyDefaults, org.apache.openjpa.jdbc.schema.Table, org.apache.openjpa.jdbc.meta.ClassMapping, org.apache.openjpa.jdbc.meta.ClassMapping, boolean, boolean).
getColumnIO() - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
getColumnIO() - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
getColumnIO() - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
getColumnIO() - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
getColumnIO() - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
I/O information on the foreign key, or columns if this value doesn't have a key.
getColumnIO() - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
getColumnIO() - Method in class org.apache.openjpa.jdbc.meta.Version
I/O information on the version columns.
getColumnName() - Method in class org.apache.openjpa.jdbc.schema.Constraint
Return the column's name.
getColumnNameForMetadata(String) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Returns the column name that will be used for obtaining information from DatabaseMetaData.
getColumnNameForMetadata(String) - Method in class org.apache.openjpa.jdbc.sql.InterbaseDictionary
 
getColumnPrivileges(String, String, String, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getColumnResults() - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping
Ids of mapped scalar columns in the result.
getColumns() - Method in class org.apache.openjpa.jdbc.meta.DelegatingJoinable
 
getColumns() - Method in class org.apache.openjpa.jdbc.meta.Discriminator
Columns used by this Discriminator.
getColumns(Discriminator, Column[], boolean) - Method in class org.apache.openjpa.jdbc.meta.DiscriminatorMappingInfo
Return the columns set for this discriminator, based on the given templates.
getColumns() - Method in interface org.apache.openjpa.jdbc.meta.Embeddable
Return the columns used by this strategy.
getColumns() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
getColumns() - Method in interface org.apache.openjpa.jdbc.meta.Joinable
The columns managed by this joinable.
getColumns() - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Raw column data.
getColumns() - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
getColumns() - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
getColumns() - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
getColumns() - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
getColumns() - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
The columns that hold the data for this value.
getColumns() - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
getColumns(ValueMapping, String, Column[], Table, boolean) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingInfo
Return the columns for this value, based on the given templates.
getColumns() - Method in class org.apache.openjpa.jdbc.meta.Version
Columns used for versioning.
getColumns(Version, Column[], boolean) - Method in class org.apache.openjpa.jdbc.meta.VersionMappingInfo
Return the columns set for this version, based on the given templates.
getColumns() - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Return the local columns in the foreign key local table order.
getColumns() - Method in class org.apache.openjpa.jdbc.schema.LocalConstraint
Return all the columns the constraint spans.
getColumns() - Method in class org.apache.openjpa.jdbc.schema.Table
Return the table's columns, in alphabetical order.
getColumns(DatabaseMetaData, String, String, String, String, Connection) - Method in class org.apache.openjpa.jdbc.sql.AbstractSQLServerDictionary
 
getColumns(DatabaseMetaData, String, String, String, String, Connection) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Reflect on the schema to find columns matching the given table and column patterns.
getColumns(DatabaseMetaData, String, String, String, String, Connection) - Method in class org.apache.openjpa.jdbc.sql.FoxProDictionary
 
getColumns(DatabaseMetaData, String, String, String, String, Connection) - Method in class org.apache.openjpa.jdbc.sql.HSQLDictionary
 
getColumns(DatabaseMetaData, String, String, String, String, Connection) - Method in class org.apache.openjpa.jdbc.sql.InformixDictionary
 
getColumns(DatabaseMetaData, String, String, String, String, Connection) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
getColumns(DatabaseMetaData, String, String, String, String, Connection) - Method in class org.apache.openjpa.jdbc.sql.PointbaseDictionary
 
getColumns(DatabaseMetaData, String, String, String, String, Connection) - Method in class org.apache.openjpa.jdbc.sql.SQLServerDictionary
 
getColumns(String, String, String, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getComments() - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
 
getComments() - Method in class org.apache.openjpa.jdbc.meta.FieldMappingInfo
 
getComments() - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping
 
getComments() - Method in interface org.apache.openjpa.lib.xml.Commentable
Return comments, or empty array if none.
getComments() - Method in class org.apache.openjpa.meta.ClassMetaData
 
getComments() - Method in class org.apache.openjpa.meta.FieldMetaData
 
getComments() - Method in class org.apache.openjpa.meta.NonPersistentMetaData
 
getComments() - Method in class org.apache.openjpa.meta.QueryMetaData
 
getComments() - Method in class org.apache.openjpa.meta.SequenceMetaData
 
getComparator() - Method in interface org.apache.openjpa.meta.Order
Return a comparator for ordering by this element, or null if the ordering is done in the datastore.
getCompatibility() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Backwards compatibility options.
getCompatibility() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getCompatibilityInstance() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Backwards compatibility options.
getCompatibilityInstance() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getCompilation() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getCompilation() - Method in interface org.apache.openjpa.kernel.QueryContext
Return the query's compilation state.
getCompilation() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getConcurrency() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getConfiguration() - Method in class org.apache.openjpa.enhance.PCDataGenerator
Return the configuration.
getConfiguration() - Method in interface org.apache.openjpa.jdbc.kernel.JDBCStore
Return the configuration for this runtime.
getConfiguration() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
getConfiguration() - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
 
getConfiguration() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Return the configuration provided on construction.
getConfiguration() - Method in class org.apache.openjpa.jdbc.schema.TableSchemaFactory
 
getConfiguration() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
getConfiguration() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getConfiguration() - Method in interface org.apache.openjpa.jdbc.sql.SelectExecutor
Return the select configuration.
getConfiguration() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getConfiguration() - Method in class org.apache.openjpa.jdbc.sql.SQLFactoryImpl
System configuration.
getConfiguration() - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
Return the configuration for this factory.
getConfiguration() - Method in interface org.apache.openjpa.kernel.BrokerFactory
Return the configuration for this factory.
getConfiguration() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getConfiguration() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getConfiguration() - Method in class org.apache.openjpa.kernel.DelegatingBrokerFactory
 
getConfiguration() - Method in interface org.apache.openjpa.kernel.exps.Resolver
Return the OpenJPA configuration.
getConfiguration() - Method in interface org.apache.openjpa.kernel.StoreContext
Return the configuration associated with this context.
getConfiguration() - Method in class org.apache.openjpa.lib.ant.AbstractTask
The task configuration.
getConfiguration() - Method in class org.apache.openjpa.meta.MetaDataRepository
Return the configuration for the repository.
getConfiguration() - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Configuration supplied on construction.
getConfiguration() - Method in class org.apache.openjpa.persistence.EntityManagerFactoryImpl
 
getConfiguration() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getConfiguration() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return the configuration associated with this entity manager.
getConfiguration() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManagerFactory
Return the configuration for this factory.
getConfiguration() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Configuration supplied on construction.
getConfiguration() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Configuration.
getConfigurationLog() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getConfigurationLog() - Method in interface org.apache.openjpa.lib.conf.Configuration
Return the log to use for configuration messages.
getConfigurationLog() - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
Returns the logging channel openjpa.Runtime by default.
getConfigurationPrefix() - Method in class org.apache.openjpa.lib.conf.AbstractProductDerivation
 
getConfigurationPrefix() - Method in interface org.apache.openjpa.lib.conf.ProductDerivation
Return the configuration prefix for properties of this product.
getConfigurationPrefixes() - Static method in class org.apache.openjpa.lib.conf.ProductDerivations
Return the recognized prefixes for configuration properties.
getConnection() - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSavepointManager.ConnectionSavepoint
Return the current Connection for this savepoint.
getConnection(JDBCStore) - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSeq
Return the connection to use based on the type of sequence.
getConnection() - Method in interface org.apache.openjpa.jdbc.kernel.JDBCStore
Return a SQL connection to the database.
getConnection() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
getConnection() - Method in class org.apache.openjpa.jdbc.schema.SimpleDriverDataSource
 
getConnection(String, String) - Method in class org.apache.openjpa.jdbc.schema.SimpleDriverDataSource
 
getConnection(Properties) - Method in class org.apache.openjpa.jdbc.schema.SimpleDriverDataSource
 
getConnection() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getConnection() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getConnection() - Method in interface org.apache.openjpa.kernel.StoreContext
Return the connection in use by the context, or a new connection if none.
getConnection() - Method in class org.apache.openjpa.lib.jdbc.DecoratingDataSource
 
getConnection(String, String) - Method in class org.apache.openjpa.lib.jdbc.DecoratingDataSource
 
getConnection() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getConnection() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getConnection() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDataSource
 
getConnection(String, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDataSource
 
getConnection() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
getConnection() - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
getConnection() - Method in class org.apache.openjpa.lib.jdbc.JDBCEvent
Return the Connection for this event.
getConnection() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getConnection() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return the connection in use by the entity manager, or a new connection if none.
getConnection2DriverName() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Class name of the non-XA connection driver.
getConnection2DriverName() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getConnection2Password() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The password for the non-XA data store connection.
getConnection2Password() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getConnection2Properties() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
These properties provide any additional information needed to establish non-XA connections.
getConnection2Properties() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getConnection2URL() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The URL for the non-XA data store connection.
getConnection2URL() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getConnection2UserName() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The user name for the non-XA data store connection.
getConnection2UserName() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getConnectionDecoratorInstances() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The ConnectionDecorators to use.
getConnectionDecoratorInstances() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getConnectionDecorators() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
A comma-separated list of the ConnectionDecorator for adding functionality to JDBC connections.
getConnectionDecorators() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getConnectionDriverName() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Class name of the connection driver.
getConnectionDriverName() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getConnectionDriverName() - Method in interface org.apache.openjpa.jdbc.schema.DriverDataSource
Driver class name.
getConnectionDriverName() - Method in class org.apache.openjpa.jdbc.schema.SimpleDriverDataSource
 
getConnectionFactory() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The connection factory, possibly from JNDI.
getConnectionFactory() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getConnectionFactory() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getConnectionFactory2() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The non-XA connection factory.
getConnectionFactory2() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getConnectionFactory2() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getConnectionFactory2Name() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The name for the second data store connection factory.
getConnectionFactory2Name() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getConnectionFactory2Properties() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Configuration properties for the non-XA connection factory.
getConnectionFactory2Properties() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getConnectionFactoryMode() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The mode of the connection factory in use.
getConnectionFactoryMode() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getConnectionFactoryName() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The name for the data store connection factory.
getConnectionFactoryName() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getConnectionFactoryProperties() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Configuration properties for the connection factory.
getConnectionFactoryProperties() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getConnectionFactoryProperties() - Method in interface org.apache.openjpa.jdbc.schema.DriverDataSource
Configuration of datasource properties.
getConnectionFactoryProperties() - Method in class org.apache.openjpa.jdbc.schema.SimpleDriverDataSource
 
getConnectionPassword() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The password for the data store connection.
getConnectionPassword() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getConnectionPassword() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getConnectionPassword() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getConnectionPassword() - Method in interface org.apache.openjpa.kernel.StoreContext
Return the connection password.
getConnectionPassword() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getConnectionPassword() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return the connection password.
getConnectionProperties() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
These properties provide any additional information needed to establish connections.
getConnectionProperties() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getConnectionProperties() - Method in interface org.apache.openjpa.jdbc.schema.DriverDataSource
Configuration of connection.
getConnectionProperties() - Method in class org.apache.openjpa.jdbc.schema.SimpleDriverDataSource
 
getConnectionRetainMode() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Specifies the behavior of the broker with respect to data store connections.
getConnectionRetainMode() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getConnectionRetainMode() - Method in interface org.apache.openjpa.kernel.Broker
Return the connection retain mode for this broker.
getConnectionRetainMode() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getConnectionRetainMode() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getConnectionRetainMode() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getConnectionRetainMode() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return the connection retain mode for this entity manager.
getConnectionRetainModeConstant() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Return the connection retain mode as one of the following symbolic constants: ConnectionRetainModes.CONN_RETAIN_ALWAYS ConnectionRetainModes.CONN_RETAIN_TRANS ConnectionRetainModes.CONN_RETAIN_DEMAND
getConnectionRetainModeConstant() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getConnectionURL() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The URL for the data store connection.
getConnectionURL() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getConnectionURL() - Method in interface org.apache.openjpa.jdbc.schema.DriverDataSource
JDBC URL.
getConnectionURL() - Method in class org.apache.openjpa.jdbc.schema.SimpleDriverDataSource
 
getConnectionUserName() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The user name for the data store connection.
getConnectionUserName() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getConnectionUserName() - Method in interface org.apache.openjpa.jdbc.schema.DriverDataSource
JDBC user name.
getConnectionUserName() - Method in class org.apache.openjpa.jdbc.schema.SimpleDriverDataSource
 
getConnectionUserName() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getConnectionUserName() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getConnectionUserName() - Method in interface org.apache.openjpa.kernel.StoreContext
Return the connection user name.
getConnectionUserName() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getConnectionUserName() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return the connection user name.
getConstant(Column) - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Return the constant value assigned to the given local column.
getConstantColumns() - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Return the local columns that we link to using constant values.
getConstantPrimaryKeyColumns() - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Return the primary key columns that we link to using constant values.
getConstants() - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Return the constant values assigned to the local columns returned by ForeignKey.getConstantColumns().
getContent() - Method in interface org.apache.openjpa.lib.meta.MetaDataFilter.Resource
Resource content.
getContent() - Method in class org.apache.openjpa.lib.meta.ZipFileMetaDataIterator
 
getContent() - Method in class org.apache.openjpa.lib.meta.ZipStreamMetaDataIterator
 
getContext() - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
Returns the StoreContext that this store manager is associated with.
getContext() - Method in class org.apache.openjpa.datacache.QueryCacheStoreQuery
 
getContext() - Method in interface org.apache.openjpa.jdbc.kernel.JDBCStore
Current persistence context.
getContext() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
getContext() - Method in class org.apache.openjpa.kernel.AbstractLockManager
 
getContext() - Method in class org.apache.openjpa.kernel.AbstractPCResultObjectProvider
Return the context this provider was constructed with.
getContext() - Method in class org.apache.openjpa.kernel.AbstractStoreQuery
 
getContext() - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
getContext() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
getContext() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
getContext() - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Return the context assiciated with this configuration; may be null if it has not been set or this object has been serialized.
getContext() - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
getContext() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
getContext() - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return the managing context.
getContext() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
getContext() - Method in interface org.apache.openjpa.kernel.StoreQuery
Return the query context that has been set.
getCopyFieldState() - Method in class org.apache.openjpa.kernel.OpenJPASavepoint
Whether this savepoint copies the field values of retained instances.
getCopyObjectIds() - Method in class org.apache.openjpa.conf.Compatibility
Whether to copy identity objects before returning them to client code.
getCount(JDBCStore) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
getCount(JDBCStore) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getCount(JDBCStore) - Method in interface org.apache.openjpa.jdbc.sql.SelectExecutor
Return the number of instances matching this select.
getCount(JDBCStore) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getCreateFieldMethods(int) - Method in class org.apache.openjpa.enhance.DynamicStorageGenerator
Return the policy constant for how to create type methods.
getCreateFieldMethods(int) - Method in class org.apache.openjpa.enhance.PCDataGenerator
 
getCreateIndexSQL(Index) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return a series of SQL statements to create the given index.
getCreateIndexSQL(Index) - Method in class org.apache.openjpa.jdbc.sql.FoxProDictionary
 
getCreateSequenceSQL(Sequence) - Method in class org.apache.openjpa.jdbc.sql.DB2Dictionary
 
getCreateSequenceSQL(Sequence) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return a series of SQL statements to create the given sequence.
getCreateSequenceSQL(Sequence) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
getCreateSequenceSQL(Sequence) - Method in class org.apache.openjpa.jdbc.sql.PostgresDictionary
 
getCreateTableSQL(Table) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return a series of SQL statements to create the given table, complete with columns.
getCreateTableSQL(Table) - Method in class org.apache.openjpa.jdbc.sql.HSQLDictionary
 
getCreateTableSQL(Table) - Method in class org.apache.openjpa.jdbc.sql.InformixDictionary
 
getCreateTableSQL(Table) - Method in class org.apache.openjpa.jdbc.sql.MySQLDictionary
 
getCreateTableSQL(Table) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
getCreateTableSQL(Table) - Method in class org.apache.openjpa.jdbc.sql.SybaseDictionary
 
getCrossReference(String, String, String, String, String, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getCurrentDate() - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
getCurrentDate() - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return a value representing the current date.
getCurrentDate() - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
getCurrentTime() - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
getCurrentTime() - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return a value representing the current time.
getCurrentTime() - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
getCurrentTimestamp() - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
getCurrentTimestamp() - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return a value representing the current timestamp.
getCurrentTimestamp() - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
getCursorName() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getCustomFetchGroups() - Method in class org.apache.openjpa.meta.ClassMetaData
Return all fetch groups for this type, including superclass groups.
getCustomFetchGroups() - Method in class org.apache.openjpa.meta.FieldMetaData
Gets the name of the custom fetch groups those are associated to this receiver.
getCustomizer() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Return the customizer in use, or null if none.
getData(int) - Method in class org.apache.openjpa.datacache.DataCachePCDataImpl
 
getData(int) - Method in interface org.apache.openjpa.kernel.PCData
Return the data stored in the given field index.
getData(int) - Method in class org.apache.openjpa.kernel.PCDataImpl
 
getData(ClassMetaData, Object) - Method in class org.apache.openjpa.xmlstore.XMLStore
Return the data for the given oid, or null if it does not exist.
getData(ClassMetaData) - Method in class org.apache.openjpa.xmlstore.XMLStore
Return all datas for the base class of the given type.
getDatabaseMajorVersion() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getDatabaseMinorVersion() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getDatabaseProductName() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getDatabaseProductVersion() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getDataCache() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The DataCache to use for level-2 data store caching.
getDataCache() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getDataCache(String) - Method in interface org.apache.openjpa.datacache.DataCacheManager
Return the named data cache, or null if it does not exist.
getDataCache(String, boolean) - Method in interface org.apache.openjpa.datacache.DataCacheManager
Return the named data cache.
getDataCache(String) - Method in class org.apache.openjpa.datacache.DataCacheManagerImpl
 
getDataCache(String, boolean) - Method in class org.apache.openjpa.datacache.DataCacheManagerImpl
 
getDataCache() - Method in class org.apache.openjpa.meta.ClassMetaData
Return the data cache for this class, or null if it is not cachable.
getDataCacheManager() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The data cache manager manages this configuration's cache instances.
getDataCacheManager() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getDataCacheManagerInstance() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The data cache manager manages this configuration's cache instances.
getDataCacheManagerInstance() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getDataCacheName() - Method in class org.apache.openjpa.meta.ClassMetaData
The name of the datacache to use for this class, or null if none.
getDataCacheScheduler() - Method in interface org.apache.openjpa.datacache.DataCacheManager
Return the runnable which schedules evictions.
getDataCacheScheduler() - Method in class org.apache.openjpa.datacache.DataCacheManagerImpl
 
getDataCacheTimeout() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Default data cache timeout.
getDataCacheTimeout() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getDataCacheTimeout() - Method in class org.apache.openjpa.meta.ClassMetaData
The cache timeout for this class.
getDataSource(StoreContext) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Return the primary data source to use.
getDataSource(StoreContext) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getDataSource2(StoreContext) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Return the non-enlisted data source to use.
getDataSource2(StoreContext) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getDataStoreActions(ClassMetaData, ClassMetaData[], boolean, ExpressionFactory[], QueryExpressions[], Object[], StoreQuery.Range) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreQuery
 
getDataStoreActions(StoreQuery, Object[], StoreQuery.Range) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery.AbstractExecutor
 
getDataStoreActions(Map) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getDataStoreActions(StoreQuery.Executor, ClassMetaData, ClassMetaData[], boolean, ExpressionFactory[], QueryExpressions[], Object[], StoreQuery.Range) - Method in class org.apache.openjpa.kernel.ExpressionStoreQuery
Return the commands that will be sent to the datastore in order to execute the query, typically in the database's native language.
getDataStoreActions(Map) - Method in interface org.apache.openjpa.kernel.Query
Returns a description of the commands that will be sent to the datastore in order to execute this query.
getDataStoreActions(Map) - Method in class org.apache.openjpa.kernel.QueryImpl
 
getDataStoreActions(StoreQuery, Object[], StoreQuery.Range) - Method in interface org.apache.openjpa.kernel.StoreQuery.Executor
Return a description of the commands that will be sent to the datastore in order to execute the query.
getDataStoreActions(Map) - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Returns a description of the commands that will be sent to the datastore in order to execute this query.
getDataStoreActions(Map) - Method in class org.apache.openjpa.persistence.QueryImpl
 
getDataStoreIdColumnName() - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default base name for datastore identity columns, or null to the mapping's built-in name.
getDataStoreIdColumns(ClassMapping, Column[], Table, boolean) - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
Return the datastore identity columns for the given class, based on the given templates.
getDataStoreIdSequence(ClassMetaData) - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
Returns the system-configured sequence.
getDataStoreIdSequence(ClassMetaData) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
getDataStoreIdSequence(ClassMetaData) - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
getDataStoreIdSequence(ClassMetaData) - Method in interface org.apache.openjpa.kernel.StoreManager
Return a sequence that generates datastore identity values for the given class.
getDataStoreIdType(ClassMetaData) - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
 
getDataStoreIdType(ClassMetaData) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
getDataStoreIdType(ClassMetaData) - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
getDataStoreIdType(ClassMetaData) - Method in interface org.apache.openjpa.kernel.StoreManager
Return the class used by this StoreManager for datastore identity values.
getDataStoreSavepoint() - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSavepointManager.ConnectionSavepoint
Return the stored savepoint object
getDate(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getDate(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getDate(Object, Calendar) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getDate(Column, Calendar, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getDate(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getDate(ResultSet, int, Calendar) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getDate(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getDate(Object, Calendar) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getDate(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getDate(Column, Calendar, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getDate(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.PostgresDictionary
 
getDate(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id.
getDate(Object, Calendar) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id; may not be supported by results that are not backed by a SQL result set.
getDate(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column.
getDate(Column, Calendar, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column; may not be supported by results that are not backed by a SQL result set.
getDate(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getDate(int, Calendar) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getDate(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getDate(String, Calendar) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getDate(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getDate(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getDate(int, Calendar) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getDate(String, Calendar) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getDateInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getDateInternal(Object, Calendar, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getDateInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getDateInternal(Object, Calendar, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getDateTypeCode(Class) - Static method in class org.apache.openjpa.jdbc.meta.JavaSQLTypes
Return the proper date typecode.
getDBDictionary() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The DBDictionary to use to define the RDBMS SQL information.
getDBDictionary() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getDBDictionary() - Method in interface org.apache.openjpa.jdbc.kernel.JDBCStore
Return the dictionary in use.
getDBDictionary() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
getDBDictionary() - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Convenient access to dictionary for mappings.
getDBDictionary() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
getDBDictionary() - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
Return the dictionary in use.
getDBDictionaryInstance() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The DBDictionary to use.
getDBDictionaryInstance() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getDBSchemaGroup() - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Return the database schema.
getDecimalDigits() - Method in class org.apache.openjpa.jdbc.schema.Column
Return the number of decimal digits for the column, if applicable.
getDeclaration(FieldMetaData) - Method in class org.apache.openjpa.enhance.CodeGenerator
Return a code template for the declaration of the given field, or null to use the system-generated default Java code.
getDeclaration(FieldMapping) - Method in class org.apache.openjpa.jdbc.meta.PropertiesReverseCustomizer
 
getDeclaration(FieldMapping) - Method in interface org.apache.openjpa.jdbc.meta.ReverseCustomizer
Return a code template for the declaration of the given field, or null to use the system-generated default Java code.
getDeclareColumnSQL(Column, boolean) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return the declaration SQL for the given column.
getDeclareColumnSQL(Column, boolean) - Method in class org.apache.openjpa.jdbc.sql.SybaseDictionary
 
getDeclaredCallbacks(int) - Method in class org.apache.openjpa.meta.LifecycleMetaData
Return the declared callbacks for the given event type.
getDeclaredFetchGroups() - Method in class org.apache.openjpa.meta.ClassMetaData
Return the fetch groups declared explicitly in this type.
getDeclaredField(int) - Method in class org.apache.openjpa.meta.ClassMetaData
Return the metadata for the persistent or transactional field with the given relative index.
getDeclaredField(String) - Method in class org.apache.openjpa.meta.ClassMetaData
Return the metadata for the persistent or transactional field with the given name, without including superclass fields.
getDeclaredFieldMapping(int) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Convenience method to perform cast from ClassMetaData.getDeclaredField(int).
getDeclaredFieldMapping(String) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Convenience method to perform cast from ClassMetaData.getDeclaredField(int).
getDeclaredFieldMappings() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Convenience method to perform cast from ClassMetaData.getDeclaredFields().
getDeclaredFields() - Method in class org.apache.openjpa.meta.ClassMetaData
Return only the fields for this class, without superclass fields.
getDeclaredIncludes() - Method in class org.apache.openjpa.meta.FetchGroup
Return the fetch group names declared included by this group.
getDeclaredIndex() - Method in class org.apache.openjpa.meta.FieldMetaData
The relative index of this persistent/transactional field.
getDeclaredInterfaces() - Method in class org.apache.openjpa.meta.ClassMetaData
Return all explicitly declared interfaces this class implements.
getDeclaredRecursionDepth(FieldMetaData) - Method in class org.apache.openjpa.meta.FetchGroup
Return the recursion depth declared for the given field, or 0 if none.
getDeclaredRecursionDepthFields() - Method in class org.apache.openjpa.meta.FetchGroup
Return the fields with declared recursion depths in this group.
getDeclaredType() - Method in class org.apache.openjpa.meta.FieldMetaData
 
getDeclaredType() - Method in interface org.apache.openjpa.meta.ValueMetaData
Return the declared class of the value.
getDeclaredType() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
getDeclaredTypeCode() - Method in class org.apache.openjpa.meta.FieldMetaData
 
getDeclaredTypeCode() - Method in interface org.apache.openjpa.meta.ValueMetaData
Return the declared type code of the value.
getDeclaredTypeCode() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
getDeclaredTypeMapping() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
getDeclaredTypeMapping() - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
Convenience method to perform cast from ValueMetaData.getDeclaredTypeMetaData().
getDeclaredTypeMapping() - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
getDeclaredTypeMetaData() - Method in class org.apache.openjpa.meta.FieldMetaData
 
getDeclaredTypeMetaData() - Method in interface org.apache.openjpa.meta.ValueMetaData
Return metadata for the value's class, if the type is persistent.
getDeclaredTypeMetaData() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
getDeclaredUnmanagedFieldMappings() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Convenience method to perform cast from ClassMetaData.getDeclaredUnmanagedFields().
getDeclaredUnmanagedFields() - Method in class org.apache.openjpa.meta.ClassMetaData
Return any fields that were added as non-managed.
getDeclaredVariableType(String) - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
Returns the type of the named variabe if it has been declared.
getDeclaringMapping() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Convenience method to perform cast from FieldMetaData.getDeclaringMetaData()
getDeclaringMetaData() - Method in class org.apache.openjpa.meta.FieldMetaData
The declaring class.
getDeclaringType() - Method in class org.apache.openjpa.meta.FieldMetaData
The declaring class.
getDecorators() - Method in class org.apache.openjpa.lib.jdbc.DecoratingDataSource
Return a read-only list of connection decorators in the order they were added.
getDefault() - Method in class org.apache.openjpa.jdbc.schema.Column
Return the default value set for this column, if any.
getDefault() - Method in class org.apache.openjpa.lib.conf.Value
The default value for the property as a string.
getDefaultAccessType() - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
The default access type for base classes with ACCESS_UNKNOWN.
getDefaultAccessType() - Method in interface org.apache.openjpa.meta.MetaDataDefaults
Return the default access type for a base persistent class with ClassMetaData.ACCESS_UNKNOWN access type.
getDefaultAccessType() - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
getDefaultEntryDelimiter() - Method in class org.apache.openjpa.lib.util.FormatPreservingProperties
See FormatPreservingProperties.setDefaultEntryDelimiter(char)
getDefaultEventIndex() - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
getDefaultFetchGroupFieldMappings() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Convenience method to perform cast from ClassMetaData.getDefaultFetchGroupFields().
getDefaultFetchGroupFields() - Method in class org.apache.openjpa.meta.ClassMetaData
Return the list of fields in the default fetch group, including superclass fields, or an empty array if none.
getDefaultIdentityType() - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
The default identity type for unmapped classes without primary key fields.
getDefaultIdentityType() - Method in interface org.apache.openjpa.meta.MetaDataDefaults
Return the default identity type for unmapped classes without primary key fields.
getDefaultIdentityType() - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
getDefaultLevel() - Method in class org.apache.openjpa.lib.log.LogFactoryImpl
The default level for unconfigured log channels.
getDefaultPropertyIndex() - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
getDefaults() - Method in class org.apache.openjpa.meta.DelegatingMetaDataFactory
 
getDefaults() - Method in interface org.apache.openjpa.meta.MetaDataFactory
Return the metadata defaults for this factory.
getDefaults() - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
getDefaults() - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
 
getDefaultString() - Method in class org.apache.openjpa.jdbc.schema.Column
Return the default value set for the column, if any.
getDefaultTransactionIsolation() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getDeferConstraints() - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Whether to defer constraints by default.
getDefinedFieldMappings() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Convenience method to perform cast from ClassMetaData.getDefinedFields().
getDefinedFieldMappingsInListingOrder() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Convenience method to perform cast from ClassMetaData.getDefinedFieldsInListingOrder().
getDefinedFields() - Method in class org.apache.openjpa.meta.ClassMetaData
Returns an array of all the fields defined by this class.
getDefinedFieldsInListingOrder() - Method in class org.apache.openjpa.meta.ClassMetaData
Returns all fields defined by this class in the order they are listed in the metadata file.
getDefinedSuperclassField(String) - Method in class org.apache.openjpa.meta.ClassMetaData
Return the defined superclass field with the given name, or null if none.
getDefiningMapping() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Convenience method to perform cast from FieldMetaData.getDefiningMetaData()
getDefiningMetaData(QueryMetaData, Map) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Return the metadata that defines the given query, if any.
getDefiningMetaData() - Method in class org.apache.openjpa.meta.FieldMetaData
The class that defines the metadata for this field.
getDefiningType() - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping
The class that defines this query result, or null if none.
getDefiningType() - Method in class org.apache.openjpa.meta.QueryMetaData
The class that defines this query, or null if none.
getDelayConstraintResolve() - Method in interface org.apache.openjpa.jdbc.schema.SchemaParser
Delay resolution of foreign key constraints until SchemaParser.resolveConstraints() is called.
getDelayConstraintResolve() - Method in class org.apache.openjpa.jdbc.schema.XMLSchemaParser
 
getDelegate() - Method in class org.apache.openjpa.datacache.DelegatingDataCache
Return the direct delegate.
getDelegate() - Method in class org.apache.openjpa.datacache.DelegatingQueryCache
Return the direct delegate.
getDelegate() - Method in class org.apache.openjpa.datacache.QueryCacheStoreQuery
Delegate.
getDelegate() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
Delegate select.
getDelegate() - Method in class org.apache.openjpa.kernel.DelegatingBroker
Return the direct delegate.
getDelegate() - Method in class org.apache.openjpa.kernel.DelegatingBrokerFactory
Return the direct delegate.
getDelegate() - Method in class org.apache.openjpa.kernel.DelegatingExtent
Return the direct delegate.
getDelegate() - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
Return the direct delegate.
getDelegate() - Method in class org.apache.openjpa.kernel.DelegatingQuery
Return the direct delegate.
getDelegate() - Method in class org.apache.openjpa.kernel.DelegatingResultList.DelegatingListIterator
Return the direct delegate.
getDelegate() - Method in class org.apache.openjpa.kernel.DelegatingResultList
Return the direct delegate.
getDelegate() - Method in class org.apache.openjpa.kernel.DelegatingSeq
Return the direct delegate.
getDelegate() - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
Return the wrapped store manager.
getDelegate() - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
getDelegate() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
Return the wrapped statement.
getDelegate() - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
Return the wrapped connection.
getDelegate() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDataSource
Return the wrapped data source.
getDelegate() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
Return the wrapped statement.
getDelegate() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
Return the wrapped result set.
getDelegate() - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
Return the wrapped statement.
getDelegate() - Method in class org.apache.openjpa.lib.log.CommonsLogFactory.LogAdapter
 
getDelegate() - Method in class org.apache.openjpa.lib.log.Log4JLogFactory.LogAdapter
 
getDelegate() - Method in class org.apache.openjpa.lib.rop.ListResultList
Return the wrapped list.
getDelegate() - Method in class org.apache.openjpa.lib.rop.ListResultObjectProvider
 
getDelegate() - Method in class org.apache.openjpa.meta.DelegatingMetaDataFactory
Factory delegate.
getDelegate() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getDelegate() - Method in interface org.apache.openjpa.persistence.Extent
Delegate.
getDelegate() - Method in class org.apache.openjpa.persistence.ExtentImpl
 
getDelegate() - Method in interface org.apache.openjpa.persistence.FetchPlan
Delegate.
getDelegate() - Method in class org.apache.openjpa.persistence.FetchPlanImpl
Delegate.
getDelegate() - Method in interface org.apache.openjpa.persistence.Generator
Delegate.
getDelegate() - Method in class org.apache.openjpa.persistence.GeneratorImpl
 
getDelegate() - Method in class org.apache.openjpa.persistence.QueryImpl
Delegate.
getDelegate() - Method in interface org.apache.openjpa.persistence.QueryResultCache
Delegate.
getDelegate() - Method in class org.apache.openjpa.persistence.QueryResultCacheImpl
 
getDelegate() - Method in interface org.apache.openjpa.persistence.StoreCache
Delegate.
getDelegate() - Method in class org.apache.openjpa.persistence.StoreCacheImpl
 
getDelegates() - Method in class org.apache.openjpa.lib.log.MultiLogFactory
Returns the delegates that this MultiLogFactory delegates messages to.
getDeleteAction() - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Return the delete action for the key.
getDeletedObjectIds() - Method in class org.apache.openjpa.event.RemoteCommitEvent
When the event type is not PAYLOAD_EXTENTS, return the set of object IDs for deleted objects.
getDeletedTypeNames() - Method in class org.apache.openjpa.event.RemoteCommitEvent
When the event type is PAYLOAD_EXTENTS, return the set of class names for the classes of deleted objects.
getDeletedTypes() - Method in class org.apache.openjpa.event.TransactionEvent
Return the unmodifiable the set of classes of persistence capable objects that were deleted in the transaction.
getDeletedTypes() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getDeletedTypes() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getDeletedTypes() - Method in interface org.apache.openjpa.kernel.StoreContext
Return the set of classes that have been deleted in the current transaction.
getDeletes() - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy.CustomUpdate
 
getDeletes() - Method in class org.apache.openjpa.jdbc.sql.RowManagerImpl
Return all deleted primary rows.
getDescribedType() - Method in class org.apache.openjpa.meta.ClassMetaData
The persistence capable class described by this metadata.
getDescribedType() - Method in class org.apache.openjpa.meta.NonPersistentMetaData
Persistence-aware type.
getDescription() - Method in class org.apache.openjpa.jdbc.schema.Column
Useful for debugging.
getDetachable() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Whether to make generated classes detachable.
getDetachedObjectId(AttachManager, Object) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
getDetachedState() - Method in class org.apache.openjpa.meta.ClassMetaData
The name of the detach state field, or null if none.
getDetachedStateField() - Method in class org.apache.openjpa.conf.DetachOptions
Whether to add a detached state field to enhanced classes.
getDetachedStateField() - Method in class org.apache.openjpa.meta.ClassMetaData
Return the detach state field, or null if none.
getDetachedStateManager() - Method in class org.apache.openjpa.conf.DetachOptions
Whether to use a detached state manager on types that allow it.
getDetachState() - Method in class org.apache.openjpa.conf.DetachOptions.All
 
getDetachState() - Method in class org.apache.openjpa.conf.DetachOptions.FetchGroups
 
getDetachState() - Method in class org.apache.openjpa.conf.DetachOptions
The DetachState constant.
getDetachState() - Method in class org.apache.openjpa.conf.DetachOptions.Loaded
 
getDetachState() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getDetachState() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getDetachState() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getDetachState() - Method in interface org.apache.openjpa.kernel.StoreContext
Detach mode constant to determine which fields are part of the detached graph.
getDetachState() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getDetachState() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Detach mode constant to determine which fields are part of the detached graph.
getDetachStateInstance() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Return the instance specified by the detach state plugin.
getDetachStateInstance() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getDiagnosticContext() - Method in class org.apache.openjpa.lib.log.LogFactoryImpl
A string to prefix all log messages with.
getDirectory() - Method in class org.apache.openjpa.enhance.ApplicationIdTool
The directory to write source to.
getDirectory() - Method in class org.apache.openjpa.enhance.PCEnhancer
The base build directory to generate code to.
getDirectory() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
The file to output the generated code to, or null for the current directory.
getDirty() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
getDirty() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
getDirty() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
getDirty() - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return a read-only mask of the indexes of all dirty fields.
getDirty() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
getDirtyObjects() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getDirtyObjects() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getDirtyObjects() - Method in interface org.apache.openjpa.kernel.StoreContext
Return a list of current dirty instances.
getDirtyObjects() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getDirtyObjects() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return a set of current dirty instances.
getDirtyStates() - Method in class org.apache.openjpa.kernel.BrokerImpl
Return a copy of all dirty state managers.
getDiscriminator() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
The class discriminator.
getDiscriminatorColumnName() - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default base name for discriminator columns, or null to the mapping's built-in name.
getDiscriminatorStrategy() - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default discriminator strategy alias.
getDiscriminatorStrategy() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Default discriminator strategy for base class mappings.
getDiscriminatorValue(Discriminator, boolean) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Return the default discriminator value for the given instance.
getDiscriminatorValue(Discriminator, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
getDiscriminatorValue(Discriminator, boolean) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
getDiscriminatorValue(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.ClassNameDiscriminatorStrategy
 
getDiscriminatorValue(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.InValueDiscriminatorStrategy
Return the discriminator value for the given type.
getDiscriminatorValue(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.ValueMapDiscriminatorStrategy
 
getDocType() - Method in class org.apache.openjpa.jdbc.schema.XMLSchemaParser
 
getDocType() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Override this method to return any DOCTYPE declaration that should be dynamically included in xml documents that will be validated.
getDocument() - Static method in class org.apache.openjpa.lib.xml.XMLFactory
Return a new DOM Document.
getDOMParser(boolean, boolean) - Static method in class org.apache.openjpa.lib.xml.XMLFactory
Return a DocumentBuilder with the specified configuration.
getDouble(int) - Method in interface org.apache.openjpa.enhance.DynamicStorage
Get the double at the given index.
getDouble(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getDouble(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getDouble(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getDouble(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getDouble(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getDouble(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id.
getDouble(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column.
getDouble(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getDouble(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getDouble(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getDouble(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getDoubleExtension(String) - Method in class org.apache.openjpa.meta.Extensions
Get the value as a double.
getDoubleExtension(String, String) - Method in class org.apache.openjpa.meta.Extensions
Get the value as a double.
getDoubleInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getDoubleInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getDoubleProperty(String, String, double) - Method in class org.apache.openjpa.lib.util.Options
Specialization of TypedProperties.getDoubleProperty(java.lang.String) to allow a value to appear under either of two keys; useful for short and long versions of command-line flags.
getDoubleProperty(String) - Method in class org.apache.openjpa.lib.util.TypedProperties
Return the property under the given key as a double, or 0 if it does not exist and has no set default.
getDoubleProperty(String, double) - Method in class org.apache.openjpa.lib.util.TypedProperties
Return the property under the given key as a double, or the given default if it does not exist.
getDoubleSpace() - Method in class org.apache.openjpa.lib.jdbc.SQLFormatter
If true, then output two lines after multi-line statements.
getDriverDataSource() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The DriverDataSource to use for creating a DataSource from a JDBC Driver.
getDriverDataSource() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getDriverMajorVersion() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getDriverMinorVersion() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getDriverName() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getDriverVersion() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getDropColumnSQL(Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return a series of SQL statements to drop the given column from its table.
getDropColumnSQL(Column) - Method in class org.apache.openjpa.jdbc.sql.EmpressDictionary
 
getDropColumnSQL(Column) - Method in class org.apache.openjpa.jdbc.sql.InterbaseDictionary
 
getDropColumnSQL(Column) - Method in class org.apache.openjpa.jdbc.sql.SybaseDictionary
 
getDropForeignKeySQL(ForeignKey) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return a series of SQL statements to drop the given foreign key from its table.
getDropIndexSQL(Index) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return a series of SQL statements to drop the given index.
getDropIndexSQL(Index) - Method in class org.apache.openjpa.jdbc.sql.MySQLDictionary
 
getDropPrimaryKeySQL(PrimaryKey) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return a series of SQL statements to drop the given primary key from its table.
getDropPrimaryKeySQL(PrimaryKey) - Method in class org.apache.openjpa.jdbc.sql.HSQLDictionary
 
getDropSequences() - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
If true, sequences that appear to be unused will be dropped.
getDropSequenceSQL(Sequence) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return a series of SQL statements to drop the given sequence.
getDropTables() - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
If true, tables that appear to be unused will be dropped.
getDropTableSQL(Table) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return a series of SQL statements to drop the given table.
getDropUnusedComponents() - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Whether schema components that are unused by any mapping will be dropped from this tool's SchemaGroup, and, depending on the schema action, from the database.
getDynamicDataStructs() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Return whether to generate dynamic data structures where possible for cache and runtime usage.
getDynamicDataStructs() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getEager(FieldMapping) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getEager(FieldMapping) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getEager(FieldMapping) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getEager(FieldMapping) - Method in interface org.apache.openjpa.jdbc.sql.Result
The eager result for the given key, or null if none.
getEager(FieldMapping) - Method in interface org.apache.openjpa.jdbc.sql.Select
Return the eager select for the given key.
getEager(FieldMapping) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getEager(FieldMapping) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
getEagerFetchMode() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Specifies the default eager fetch mode to use.
getEagerFetchMode() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getEagerFetchMode() - Method in class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
 
getEagerFetchMode() - Method in interface org.apache.openjpa.jdbc.kernel.JDBCFetchConfiguration
Return the eager fetch mode.
getEagerFetchMode() - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
getEagerFetchMode() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
The eager fetch mode, as one of the eager constants in JDBCFetchConfiguration.
getEagerFetchMode() - Method in interface org.apache.openjpa.persistence.jdbc.JDBCFetchPlan
Eager fetch mode in loading relations.
getEagerFetchMode() - Method in class org.apache.openjpa.persistence.jdbc.JDBCFetchPlanImpl
 
getEagerFetchModeConstant() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Return the eager fetch mode as one of the following symbolic constants: EagerFetchModes.EAGER_NONE EagerFetchModes.EAGER_JOIN EagerFetchModes.EAGER_PARALLEL
getEagerFetchModeConstant() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getEagerMap(boolean) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
Raw eager information.
getEagerMap() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
Return view of eager selects.
getElement() - Method in class org.apache.openjpa.meta.FieldMetaData
Metadata about the element value.
getElementClass() - Method in interface org.apache.openjpa.persistence.Extent
The extent's element type.
getElementClass() - Method in class org.apache.openjpa.persistence.ExtentImpl
 
getElementColumns(ClassMapping) - Method in interface org.apache.openjpa.jdbc.meta.strats.LRSCollectionFieldStrategy
Return the columns holding the data for a collection element for the given element mapping from LRSCollectionFieldStrategy.getIndependentElementMappings(boolean) (or null).
getElementColumns(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationCollectionInverseKeyFieldStrategy
 
getElementColumns(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationCollectionTableFieldStrategy
 
getElementMapping() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Convenience method to perform cast from FieldMetaData.getElement()
getElementType() - Method in class org.apache.openjpa.kernel.DelegatingExtent
 
getElementType() - Method in interface org.apache.openjpa.kernel.Extent
The class of extent elements.
getElementType() - Method in class org.apache.openjpa.kernel.ExtentImpl
 
getEmbeddedExtensions(String, boolean) - Method in class org.apache.openjpa.meta.Extensions
Return the embedded extensions under the given key.
getEmbeddedExtensions(String, String, boolean) - Method in class org.apache.openjpa.meta.Extensions
Return the embedded extensions under the given key.
getEmbeddedMapping() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
getEmbeddedMapping() - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
Convenience method to perform cast from ValueMetaData.getEmbeddedMetaData().
getEmbeddedMapping() - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
getEmbeddedMetaData() - Method in class org.apache.openjpa.meta.FieldMetaData
 
getEmbeddedMetaData() - Method in interface org.apache.openjpa.meta.ValueMetaData
The embedded class metadata for the value.
getEmbeddedMetaData() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
getEmbeddingMapping() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Convenience method to perform cast from ClassMetaData.getEmbeddingMetaData()
getEmbeddingMetaData() - Method in class org.apache.openjpa.meta.ClassMetaData
If this metadata is for an embedded object, returning the owning value.
getEmptyValue(int) - Static method in class org.apache.openjpa.jdbc.meta.JavaSQLTypes
Return an empty value object for the given type code.
getEndIndex() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getEndIndex() - Method in interface org.apache.openjpa.jdbc.sql.Select
The result end index.
getEndIndex() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getEndl() - Method in class org.apache.openjpa.lib.util.CodeFormat
Return a new line character.
getEndl(int) - Method in class org.apache.openjpa.lib.util.CodeFormat
Return the given number of new line characters.
getEndl(int, int) - Method in class org.apache.openjpa.lib.util.CodeFormat
Return the given number of new line characters, followed by the given tab level indentation.
getEndRange() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getEndRange() - Method in interface org.apache.openjpa.kernel.QueryContext
Return the 0-based exclusive end index for the returned results, or Long.MAX_VALUE for no limit.
getEndRange() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getEnforcePropertyRestrictions() - Method in class org.apache.openjpa.enhance.PCEnhancer
Whether to fail if the persistent type uses property access and bytecode analysis shows that it may be violating OpenJPA's property access restrictions.
getEntityManager() - Method in interface org.apache.openjpa.persistence.Extent
The owning entity manager.
getEntityManager() - Method in class org.apache.openjpa.persistence.ExtentImpl
 
getEntityManager(Object) - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
Return the entity manager for the given object, if one can be determined from just the object alone.
getEntityManager() - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
The owning entity manage.
getEntityManager() - Method in class org.apache.openjpa.persistence.QueryImpl
 
getEntityManagerFactory() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getEntityManagerFactory() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return the factory that produced this entity manager.
getEntityManagerFactory() - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
Returns the OpenJPAEntityManagerFactory specified by your OpenJPA defaults.
getEntityManagerFactory(Map) - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
Returns the OpenJPAEntityManagerFactory specified by your OpenJPA defaults, using map as overrides.
getEntry(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
Returns the entry associated with the specified key in the ConcurrentHashMap.
getEnumType(FieldMapping) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer
Return enum type for the field.
getEnvClassLoader() - Method in class org.apache.openjpa.meta.ClassMetaData
The environmental loader used when loading this metadata.
getEnvClassLoader() - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Return the environmental class loader to pass on to parsed metadata instances.
getEnvClassLoader() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Return the environmental class loader to pass on to parsed metadata instances.
getErrorCode() - Method in exception org.apache.openjpa.lib.jdbc.ReportingSQLException
Returns the error code of the underlying SQLException.
getEventSetDescriptors() - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
getEvictFromDataCache() - Method in interface org.apache.openjpa.kernel.Broker
Whether to also evict an object from the store cache when it is evicted through this broker.
getEvictFromDataCache() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getEvictFromDataCache() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getEvictFromStoreCache() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getEvictFromStoreCache() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether to also evict an object from the store cache when it is evicted through this entity manager.
getEvictionSchedule() - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
getException(String) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Returns a SAXException with the source file name and the given error message.
getException(Localizer.Message) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Returns a SAXException with the source file name and the given error message.
getException(Localizer.Message, Throwable) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Returns a SAXException with the source file name and the given error message.
getExceptions() - Method in interface org.apache.openjpa.jdbc.kernel.PreparedStatementManager
Return the exceptions encountered during all flushes.
getExcludes(List) - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping.PCResult
Return the field indexes to exclude when loading data for the given path.
getExpectedJavaType() - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedBlobFieldStrategy
 
getExpectedJavaType() - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedByteArrayFieldStrategy
 
getExpectedJavaType() - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedCharArrayFieldStrategy
 
getExpectedJavaType() - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedClobFieldStrategy
 
getExpired() - Method in class org.apache.openjpa.datacache.ExpirationEvent
Return whether the expired object was expired naturally, or if the object was explicitly removed.
getExportedKeys(String, String, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getExpressionFactory(ClassMetaData) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreQuery
 
getExpressionFactory(ClassMetaData) - Method in class org.apache.openjpa.kernel.ExpressionStoreQuery
Return an ExpressionFactory to use to create an expression to be executed against an extent.
getExtendsDec(int) - Method in class org.apache.openjpa.lib.util.CodeFormat
Extends declaration.
getExtensionKeys() - Method in class org.apache.openjpa.meta.Extensions
Return all extension keys.
getExtensionKeys(String) - Method in class org.apache.openjpa.meta.Extensions
Return all extension keys for the given vendor.
getExtensionVendors() - Method in class org.apache.openjpa.meta.Extensions
Return all vendors who have extension keys at this level.
getExternalizer() - Method in class org.apache.openjpa.meta.FieldMetaData
The name of this field's externalizer, or null if none.
getExternalizerMethod() - Method in class org.apache.openjpa.meta.FieldMetaData
The externalizer method.
getExternalValue(Object, StoreContext) - Method in class org.apache.openjpa.meta.FieldMetaData
Convert the given field value to its external value through the provided externalizer, or return the value as-is if no externalizer.
getExternalValueMap() - Method in class org.apache.openjpa.meta.FieldMetaData
Return the mapping of field values to external values.
getExternalValues() - Method in class org.apache.openjpa.meta.FieldMetaData
Properties string mapping field values to external values.
getExtraFieldDataIndex(int) - Method in class org.apache.openjpa.meta.ClassMetaData
Return the impl / intermediate field data index of the given field in the compacted array, or -1 if the field does not use extra data.
getExtraFieldDataLength() - Method in class org.apache.openjpa.meta.ClassMetaData
Return the number of fields that use impl or intermediate data, in order to create a compacted array for storage of said data.
getExtraNameCharacters() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getFactory() - Method in class org.apache.openjpa.meta.FieldMetaData
The name of this field's factory, or null if none.
getFactoryInitializationBanner() - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
Return an object to be written to the log when this broker factory initializes.
getFactoryMethod() - Method in class org.apache.openjpa.meta.FieldMetaData
The factory method or constructor.
getFailedObject() - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
 
getFailedObject() - Method in interface org.apache.openjpa.jdbc.sql.Row
Return the failed object to include in optimistic lock exceptions.
getFailedObject() - Method in class org.apache.openjpa.jdbc.sql.RowImpl
This implementation does not track failed objects.
getFailedObject() - Method in exception org.apache.openjpa.persistence.ArgumentException
 
getFailedObject() - Method in exception org.apache.openjpa.persistence.EntityExistsException
 
getFailedObject() - Method in exception org.apache.openjpa.persistence.EntityNotFoundException
 
getFailedObject() - Method in exception org.apache.openjpa.persistence.InvalidStateException
 
getFailedObject() - Method in exception org.apache.openjpa.persistence.NonUniqueResultException
 
getFailedObject() - Method in exception org.apache.openjpa.persistence.NoResultException
 
getFailedObject() - Method in exception org.apache.openjpa.persistence.OptimisticLockException
 
getFailedObject() - Method in exception org.apache.openjpa.persistence.PersistenceException
 
getFailedObject() - Method in exception org.apache.openjpa.persistence.RollbackException
 
getFailedObject() - Method in exception org.apache.openjpa.persistence.TransactionRequiredException
 
getFailedObject() - Method in interface org.apache.openjpa.util.ExceptionInfo
The failed object.
getFailedObject() - Method in exception org.apache.openjpa.util.OpenJPAException
The failed object.
getFatal(String) - Method in class org.apache.openjpa.lib.util.Localizer
Return the localized string matching the given key.
getFatal(String, Object) - Method in class org.apache.openjpa.lib.util.Localizer
Return the localized string matching the given key.
getFatal(String, Object, Object) - Method in class org.apache.openjpa.lib.util.Localizer
Return the localized string for the given key.
getFatal(String, Object[]) - Method in class org.apache.openjpa.lib.util.Localizer
Return the localized string matching the given key.
getFetchBatchSize() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Get the size of the batch that will be pre-selected when accessing elements in a query or relationship.
getFetchBatchSize() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getFetchBatchSize() - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
getFetchBatchSize() - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Return the fetch batch size for large result set support.
getFetchBatchSize() - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
getFetchBatchSize() - Method in interface org.apache.openjpa.persistence.FetchPlan
Return the fetch batch size for large result set support.
getFetchBatchSize() - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
getFetchConfiguration() - Method in interface org.apache.openjpa.jdbc.kernel.JDBCStore
Return the current default fetch configuration.
getFetchConfiguration() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
getFetchConfiguration() - Method in class org.apache.openjpa.jdbc.kernel.SelectResultObjectProvider
 
getFetchConfiguration() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getFetchConfiguration() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getFetchConfiguration() - Method in class org.apache.openjpa.kernel.DelegatingExtent
 
getFetchConfiguration() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getFetchConfiguration() - Method in interface org.apache.openjpa.kernel.Extent
Return the (mutable) fetch configuration for this extent.
getFetchConfiguration() - Method in class org.apache.openjpa.kernel.ExtentImpl
 
getFetchConfiguration() - Method in interface org.apache.openjpa.kernel.QueryContext
Return the fetch configuration for this query.
getFetchConfiguration() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getFetchConfiguration() - Method in interface org.apache.openjpa.kernel.StoreContext
Return the (mutable) fetch configuration for loading objects from this context.
getFetchDirection() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The JDBC fetch direction.
getFetchDirection() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getFetchDirection() - Method in class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
 
getFetchDirection() - Method in interface org.apache.openjpa.jdbc.kernel.JDBCFetchConfiguration
The fetch direction to use as a constant from ResultSet.
getFetchDirection() - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
getFetchDirection() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getFetchDirection() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
getFetchDirection() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getFetchDirection() - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
getFetchDirection() - Method in interface org.apache.openjpa.persistence.jdbc.JDBCFetchPlan
Result set fetch direction.
getFetchDirection() - Method in class org.apache.openjpa.persistence.jdbc.JDBCFetchPlanImpl
 
getFetchDirectionConstant() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Return the result set constant for the fetch direction.
getFetchDirectionConstant() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getFetchGroup(String) - Method in class org.apache.openjpa.meta.ClassMetaData
Gets a named fecth group.
getFetchGroups() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Comma-separated list of fetch group names that will be pre-set for all new FetchConfigurations.
getFetchGroups() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getFetchGroups() - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
getFetchGroups() - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Returns immutable set of names of the fetch groups that this component will use when loading objects.
getFetchGroups() - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
getFetchGroups() - Method in interface org.apache.openjpa.persistence.FetchPlan
Returns the names of the fetch groups that this component will use when loading objects.
getFetchGroups() - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
getFetchGroupsList() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
List of fetch group names that will be pre-set for all new FetchConfigurations.
getFetchGroupsList() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getFetchPlan() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getFetchPlan() - Method in interface org.apache.openjpa.persistence.Extent
Fetch configuration for controlling how iterated objects are loaded.
getFetchPlan() - Method in class org.apache.openjpa.persistence.ExtentImpl
 
getFetchPlan() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return the (mutable) fetch plan for loading objects from this entity manager.
getFetchPlan() - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Fetch plan for controlling the loading of results.
getFetchPlan() - Method in class org.apache.openjpa.persistence.QueryImpl
 
getFetchSize() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getFetchSize() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
getFetchSize() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getFetchSize() - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
getField(int) - Method in class org.apache.openjpa.meta.ClassMetaData
Return the metadata for the persistent or transactional field with the given absolute index.
getField(String) - Method in class org.apache.openjpa.meta.ClassMetaData
Return the metadata for the persistent or transactional field with the given name.
getField(int) - Method in class org.apache.openjpa.xmlstore.ObjectData
Get the data for the field with the given index.
getFieldAccess() - Method in class org.apache.openjpa.enhance.DynamicStorageGenerator
Return the default field ACCESS constant for generated fields from Constants.
getFieldCode(FieldMetaData) - Method in class org.apache.openjpa.enhance.CodeGenerator
Return a code template for the get/set methods of the given field, or null to use the system-generated default Java code.
getFieldCode(FieldMapping) - Method in class org.apache.openjpa.jdbc.meta.PropertiesReverseCustomizer
 
getFieldCode(FieldMapping) - Method in interface org.apache.openjpa.jdbc.meta.ReverseCustomizer
Return a code template for the get/set methods of the given field, or null to use the system-generated default Java code.
getFieldCount() - Method in interface org.apache.openjpa.enhance.DynamicStorage
Return the number of fields, regardless of type
getFieldGenerator(Class, String) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getFieldGenerator(Class, String) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Returns a Generator for the generated values of the specified type, or null if the field is not generated.
getFieldIndex() - Method in class org.apache.openjpa.jdbc.meta.DelegatingJoinable
 
getFieldIndex() - Method in interface org.apache.openjpa.jdbc.meta.Joinable
Return the field index of this joinable, or -1 if not a field.
getFieldIndex() - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
getFieldIndex() - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
getFieldIndex() - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
getFieldIndex() - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
getFieldMapping() - Method in interface org.apache.openjpa.jdbc.kernel.exps.FilterValue
If this is a path to a persistent field, return its mapping, else return null.
getFieldMapping(int) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Convenience method to perform cast from ClassMetaData.getField(int).
getFieldMapping(String) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Convenience method to perform cast from ClassMetaData.getField(int).
getFieldMapping() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
getFieldMapping() - Method in interface org.apache.openjpa.jdbc.meta.strats.LRSCollectionFieldStrategy
The owning field mapping.
getFieldMapping() - Method in interface org.apache.openjpa.jdbc.meta.strats.LRSMapFieldStrategy
The owning field mapping.
getFieldMapping() - Method in class org.apache.openjpa.jdbc.meta.strats.MapTableFieldStrategy
 
getFieldMapping() - Method in class org.apache.openjpa.jdbc.meta.strats.RelationCollectionInverseKeyFieldStrategy
 
getFieldMapping() - Method in class org.apache.openjpa.jdbc.meta.strats.RelationCollectionTableFieldStrategy
 
getFieldMapping() - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapInverseKeyFieldStrategy
 
getFieldMapping() - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapTableFieldStrategy
 
getFieldMapping() - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
Convenience method to perform cast from ValueMetaData.getFieldMetaData().
getFieldMapping() - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
getFieldMappings() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Convenience method to perform cast from ClassMetaData.getFields().
getFieldMappingsInListingOrder() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Convenience method to perform cast from ClassMetaData.getFieldsInListingOrder().
getFieldMetaData() - Method in class org.apache.openjpa.meta.FieldMetaData
 
getFieldMetaData() - Method in interface org.apache.openjpa.meta.ValueMetaData
Return the owning field for this value.
getFieldMetaData() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
getFieldName(int) - Method in class org.apache.openjpa.enhance.DynamicStorageGenerator
Return the name for the generated field at the given index.
getFieldName(ClassMapping, Column[], ForeignKey, String) - Method in class org.apache.openjpa.jdbc.meta.PropertiesReverseCustomizer
 
getFieldName(ClassMapping, Column[], ForeignKey, String) - Method in interface org.apache.openjpa.jdbc.meta.ReverseCustomizer
Return the field name used to map the given columns, or null to prevent the columns from being mapped.
getFieldName(String, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Return a default Java identifier-formatted name for the given column/table name.
getFieldName(String) - Method in class org.apache.openjpa.lib.util.CodeFormat
Return the field name for given suggested name, possibly adding leading underscore.
getFieldName(Member) - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
Return the field name for the given member.
getFieldNames(Class) - Static method in class org.apache.openjpa.enhance.PCRegistry
Get the field names for a PersistenceCapable class.
getFieldOverride() - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
Whether to use field-level override or class-level override.
getFields() - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
getFields() - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Returns the set of fully-qualified field names that this component will use when loading objects.
getFields() - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
getFields() - Method in class org.apache.openjpa.meta.ClassMetaData
Return all field metadatas, including superclass fields.
getFields() - Method in interface org.apache.openjpa.persistence.FetchPlan
Returns the fully qualified names of the fields that this component will use when loading objects.
getFields() - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
getFieldsInListingOrder() - Method in class org.apache.openjpa.meta.ClassMetaData
Returns all fields in the order they are listed in the metadata file.
getFieldStrategy(String) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Association of a field value type name with the handler or strategy class name.
getFieldType(Column, boolean) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Return the default field type for the given column.
getFieldTypes(Class) - Static method in class org.apache.openjpa.enhance.PCRegistry
Get the field types for a PersistenceCapable class.
getFieldValue(Object, StoreContext) - Method in class org.apache.openjpa.meta.FieldMetaData
Return the result of passing the given external value through the factory to get the field value.
getFieldValueMap() - Method in class org.apache.openjpa.meta.FieldMetaData
Return the mapping of external values to field values.
getFile() - Method in class org.apache.openjpa.enhance.CodeGenerator
Return Java file to write to.
getFile() - Method in class org.apache.openjpa.jdbc.schema.FileSchemaFactory
Return the XML resource defining this schema.
getFile() - Method in class org.apache.openjpa.lib.meta.ClassMetaDataIterator
 
getFile() - Method in class org.apache.openjpa.lib.meta.FileMetaDataIterator
 
getFile() - Method in interface org.apache.openjpa.lib.meta.MetaDataIterator
Return the last-iterated metadata resource content as a file, or null if not an extant file.
getFile() - Method in class org.apache.openjpa.lib.meta.MetaDataIteratorChain
 
getFile() - Method in class org.apache.openjpa.lib.meta.ResourceMetaDataIterator
 
getFile() - Method in class org.apache.openjpa.lib.meta.URLMetaDataIterator
 
getFile() - Method in class org.apache.openjpa.lib.meta.ZipFileMetaDataIterator
 
getFile() - Method in class org.apache.openjpa.lib.meta.ZipStreamMetaDataIterator
 
getFile(String, ClassLoader) - Static method in class org.apache.openjpa.lib.util.Files
Check the given string for a matching file.
getFile() - Method in class org.apache.openjpa.meta.MetaDataTool
The file to generate metadata to.
getFileHandler() - Method in class org.apache.openjpa.xmlstore.XMLConfiguration
Return the XMLFileHandler associated with this configuration.
getFileMap() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
Returns a Map with keys of the File to be written to, and values of a Collection of SourceTracker instances.
getFilterListener(String) - Method in class org.apache.openjpa.datacache.QueryCacheStoreQuery
 
getFilterListener(String) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreQuery
 
getFilterListener(String) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery
 
getFilterListener(String) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getFilterListener(String) - Method in class org.apache.openjpa.kernel.ExpressionStoreQuery
 
getFilterListener(String) - Method in interface org.apache.openjpa.kernel.exps.Resolver
Return the filter listener for the given tag, or null if none.
getFilterListener(String) - Method in interface org.apache.openjpa.kernel.QueryContext
Return the filter listener for the given tag, or null.
getFilterListener(String) - Method in class org.apache.openjpa.kernel.QueryImpl
 
getFilterListener(String) - Method in interface org.apache.openjpa.kernel.StoreQuery
Return the standard filter listener for the given tag, or null.
getFilterListenerInstances() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Return the query filter listeners.
getFilterListenerInstances() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getFilterListeners() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
A comma-separted list of the plugin strings of the query FilterListeners to use.
getFilterListeners() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getFilterListeners() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getFilterListeners() - Method in interface org.apache.openjpa.kernel.QueryContext
The set of filter listeners.
getFilterListeners() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getFirstResult() - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Return the 0-based start index for the returned results.
getFirstResult() - Method in class org.apache.openjpa.persistence.QueryImpl
 
getFlag(int) - Method in class org.apache.openjpa.jdbc.schema.Column
Flags are used for bookkeeping information.
getFloat(int) - Method in interface org.apache.openjpa.enhance.DynamicStorage
Get the float at the given index.
getFloat(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getFloat(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getFloat(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getFloat(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getFloat(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getFloat(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id.
getFloat(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column.
getFloat(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getFloat(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getFloat(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getFloat(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getFloatInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getFloatInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getFloatProperty(String, String, float) - Method in class org.apache.openjpa.lib.util.Options
Specialization of TypedProperties.getFloatProperty(java.lang.String) to allow a value to appear under either of two keys; useful for short and long versions of command-line flags.
getFloatProperty(String) - Method in class org.apache.openjpa.lib.util.TypedProperties
Return the property under the given key as a float, or 0 if it does not exist and has no set default.
getFloatProperty(String, float) - Method in class org.apache.openjpa.lib.util.TypedProperties
Return the property under the given key as a float, or the given default if it does not exist.
getFlushBeforeQueries() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Returns whether or not OpenJPA should automatically flush modifications to the data store before executing queries.
getFlushBeforeQueries() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getFlushBeforeQueries() - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
getFlushBeforeQueries() - Method in interface org.apache.openjpa.kernel.FetchConfiguration
The query automatic flush configuration.
getFlushBeforeQueries() - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
getFlushBeforeQueriesConstant() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Returns one of QueryFlushModes.FLUSH_TRUE, QueryFlushModes.FLUSH_FALSE, or QueryFlushModes.FLUSH_WITH_CONNECTION, as determined by parsing the string returned by OpenJPAConfiguration.getFlushBeforeQueries().
getFlushBeforeQueriesConstant() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getFlushed() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
getFlushed() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
getFlushed() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
getFlushed() - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return a read-only mask of the indexes of all fields that have been flushed since they were last changed.
getFlushed() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
getFlushMode() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getFlushMode() - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Return the current flush mode.
getFlushMode() - Method in class org.apache.openjpa.persistence.QueryImpl
 
getForeignKey() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
getForeignKey(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
getForeignKey(ValueMapping, String, Table, Table, boolean) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Return a default foreign key for the join from this value to its related type, or null for a logical foreign key only.
getForeignKey(ValueMapping, String, Table, Table, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
getForeignKey() - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Raw foreign key information.
getForeignKey(ValueMapping, String, Table, Table, boolean) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
getForeignKey() - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
If this value joins to another record, the foreign key.
getForeignKey(ClassMapping) - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
Return an equivalent of this value's foreign key, but joining to the given target, which may be an unjoined subclass of this value's related type.
getForeignKey() - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
getForeignKey(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
getForeignKey(String) - Method in class org.apache.openjpa.jdbc.schema.Table
Return the foreign key with the given name.
getForeignKey() - Method in class org.apache.openjpa.jdbc.sql.Join
 
getForeignKeyConstraintSQL(ForeignKey) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return the declaration SQL for the given foreign key, or null if it is not supported.
getForeignKeyConstraintSQL(ForeignKey) - Method in class org.apache.openjpa.jdbc.sql.MySQLDictionary
 
getForeignKeyDeleteAction() - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default foreign key action for relation keys.
getForeignKeyIO(ForeignKey) - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
Return the I/O information for the given set foreign key.
getForeignKeys() - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Whether foreign keys on existing tables should be manipulated.
getForeignKeys() - Method in class org.apache.openjpa.jdbc.schema.LazySchemaFactory
 
getForeignKeys() - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Return whether foreign keys should be generated.
getForeignKeys() - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Whether foreign keys on existing tables should be manipulated.
getForeignKeys() - Method in class org.apache.openjpa.jdbc.schema.Table
Return all foreign keys for the table.
getForeignKeySet(ForeignKey) - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
Return the value for the given foreign key.
getForeignKeyWhere(ForeignKey) - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
Return the value for the given foreign key.
getFrom(Select, boolean) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return the portion of the select statement between the FROM keyword and the WHERE keyword.
getFromSelect(Select, boolean) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return the FROM clause for a select that selects from a tmp table created by an inner select.
getFromSelect() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getFromSelect() - Method in interface org.apache.openjpa.jdbc.sql.Select
Another select instance that creates a temporary table from which this select pulls data.
getFromSelect() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getFullName() - Method in class org.apache.openjpa.jdbc.schema.Column
Return the column's full name, in the form <table>.<name>.
getFullName() - Method in class org.apache.openjpa.jdbc.schema.Constraint
Return the full name of the constraint.
getFullName() - Method in class org.apache.openjpa.jdbc.schema.Sequence
Return the sequence name, including schema, using '.' as the catalog separator.
getFullName() - Method in class org.apache.openjpa.jdbc.schema.Table
Return the table name, including schema, using '.' as the catalog separator.
getFullName(Index) - Method in class org.apache.openjpa.jdbc.sql.AbstractSQLServerDictionary
 
getFullName(Table, boolean) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Returns the full name of the table, including the schema (delimited by DBDictionary.catalogSeparator).
getFullName(Index) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Returns the full name of the index, including the schema (delimited by the result of DBDictionary.catalogSeparator).
getFullName(Sequence) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Returns the full name of the sequence, including the schema (delimited by the result of DBDictionary.catalogSeparator).
getFullName(Index) - Method in class org.apache.openjpa.jdbc.sql.PointbaseDictionary
 
getFullName() - Method in class org.apache.openjpa.meta.FieldMetaData
Deprecated. Use getFullName(boolean) instead.
getFullName(boolean) - Method in class org.apache.openjpa.meta.FieldMetaData
The field name, qualified by the owning class and optionally the embedding owner's name (if any).
getGeneratedKey(Column, Connection) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return the last generated value for the given column.
getGeneratedKey(Column, Connection) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
getGeneratedKeys() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getGeneratedKeys() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
getGeneratedKeys() - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
getGeneratedKeySequenceName(Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return the sequence name used by databases for the given autoassigned column.
getGeneratedKeyTriggerName(Column) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
Trigger name for simulating auto-assign values on the given column.
getGenericContext() - Method in interface org.apache.openjpa.enhance.StateManager
Persistence context.
getGenericContext() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
getGenericContext() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
getGenericContext() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
getGenericContext() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
getGetter(Class, String) - Static method in class org.apache.openjpa.util.ImplHelper
Return the getter method matching the given property name.
getGrouping() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getGrouping() - Method in interface org.apache.openjpa.jdbc.sql.Select
Return the grouping SQL for this select.
getGrouping() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getHandler() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
getHandler() - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
The handler used for this value, or null if none.
getHandler() - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
getHaving() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getHaving() - Method in interface org.apache.openjpa.jdbc.sql.Select
Return the HAVING clause, or null if none.
getHaving() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getHierarchyStrategy() - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
The default strategy for subclasses in this hierarchy.
getHint(String) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
getHint(String) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Returns the hint for the specific key, or null if the hint is not specified.
getHint(String) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
getHintKeys() - Method in class org.apache.openjpa.meta.QueryMetaData
Query hints.
getHintValues() - Method in class org.apache.openjpa.meta.QueryMetaData
Query hints.
getHoldability() - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
getHoldCount() - Method in class org.apache.openjpa.lib.util.concurrent.ReentrantLock
Queries the number of holds on this lock by the current thread.
getIcon(int) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
getId() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
getId() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
getId() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
getId() - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return the identifier for this state manager.
getId() - Method in interface org.apache.openjpa.kernel.PCData
Return the id of this instance.
getId() - Method in class org.apache.openjpa.kernel.PCDataImpl
 
getId() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
getId() - Method in class org.apache.openjpa.util.ByteId
 
getId() - Method in class org.apache.openjpa.util.CharId
 
getId() - Method in class org.apache.openjpa.util.DateId
 
getId() - Method in class org.apache.openjpa.util.Id
Primary key.
getId() - Method in class org.apache.openjpa.util.IntId
 
getId() - Method in class org.apache.openjpa.util.LongId
 
getId() - Method in class org.apache.openjpa.util.ObjectId
 
getId() - Method in class org.apache.openjpa.util.ShortId
 
getId() - Method in class org.apache.openjpa.util.StringId
 
getId() - Method in class org.apache.openjpa.xmlstore.ObjectData
Getter for oid.
getIdentifierAliases() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getIdentifierAliases() - Method in interface org.apache.openjpa.jdbc.sql.Select
Get the aliases for identifier columns that can be used in COUNT selects to find the number of matches.
getIdentifierAliases() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getIdentifierQuoteString() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getIdentityClassSuffix() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Suffix used to create application identity class name from a class name, or in the case of inner identity classes, the inner class name.
getIdentitySequence(ClassMetaData) - Method in interface org.apache.openjpa.kernel.Broker
Returns a Seq for the datastore identity values of the specified persistent class, or null if the class' identity cannot be represented as a sequence.
getIdentitySequence(ClassMetaData) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getIdentitySequence(ClassMetaData) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getIdentitySequenceMetaData() - Method in class org.apache.openjpa.meta.ClassMetaData
Metadata for the datastore identity sequence.
getIdentitySequenceName() - Method in class org.apache.openjpa.meta.ClassMetaData
The datastore identity sequence name, or null for none.
getIdentityStrategy() - Method in class org.apache.openjpa.meta.ClassMetaData
The strategy to use for datastore identity generation.
getIdentityType() - Method in class org.apache.openjpa.meta.ClassMetaData
The type of identity being used.
getIdGenerator(Class) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getIdGenerator(Class) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Returns a Generator for the datastore identity values of the specified type, or null if the type is unmanaged or its identity cannot be represented by a sequence.
getIdObject() - Method in class org.apache.openjpa.util.ByteId
 
getIdObject() - Method in class org.apache.openjpa.util.CharId
 
getIdObject() - Method in class org.apache.openjpa.util.DateId
 
getIdObject() - Method in class org.apache.openjpa.util.Id
 
getIdObject() - Method in class org.apache.openjpa.util.IntId
 
getIdObject() - Method in class org.apache.openjpa.util.LongId
 
getIdObject() - Method in class org.apache.openjpa.util.ObjectId
 
getIdObject() - Method in class org.apache.openjpa.util.OpenJPAId
Return the identity value as an object.
getIdObject() - Method in class org.apache.openjpa.util.ShortId
 
getIdObject() - Method in class org.apache.openjpa.util.StringId
 
getIgnoreChanges() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Whether changes in the current transaction are taken into account when executing queries and iterating extents.
getIgnoreChanges() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getIgnoreChanges() - Method in interface org.apache.openjpa.kernel.Broker
Whether to take into account changes in the transaction when executing a query or iterating an extent.
getIgnoreChanges() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getIgnoreChanges() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getIgnoreChanges() - Method in class org.apache.openjpa.kernel.DelegatingExtent
 
getIgnoreChanges() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getIgnoreChanges() - Method in interface org.apache.openjpa.kernel.Extent
Whether this extent will ignore changes made in the current transaction.
getIgnoreChanges() - Method in class org.apache.openjpa.kernel.ExtentImpl
 
getIgnoreChanges() - Method in interface org.apache.openjpa.kernel.QueryContext
Whether to ignore changes in the current transaction.
getIgnoreChanges() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getIgnoreChanges() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getIgnoreChanges() - Method in interface org.apache.openjpa.persistence.Extent
Whether the extent sees inserts and deletes in the current transaction.
getIgnoreChanges() - Method in class org.apache.openjpa.persistence.ExtentImpl
 
getIgnoreChanges() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether to take into account changes in the transaction when executing a query or iterating an extent.
getIgnoreChanges() - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Whether to ignore changes in the current transaction.
getIgnoreChanges() - Method in class org.apache.openjpa.persistence.QueryImpl
 
getIgnoreErrors() - Method in class org.apache.openjpa.enhance.ApplicationIdTool
Return false if this tool is configured to throw an exception on an attempt to generate an id class for a type that does not use application identity.
getIgnoreErrors() - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Whether and SQL errors should cause a failure or just issue a warning.
getIgnoreErrors() - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
If true, SQLExceptions thrown during schema manipulation will be printed but ignored.
getIgnoreNonPersistent() - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
 
getIgnoreSuperclassCallbacks() - Method in class org.apache.openjpa.meta.LifecycleMetaData
Whether to exclude superclass callbacks from events.
getIgnoreSystemListeners() - Method in class org.apache.openjpa.meta.LifecycleMetaData
Whether to exclude system listeners from events.
getIgnoreUnmapped() - Method in class org.apache.openjpa.jdbc.kernel.ClassTableJDBCSeq
Whether unmapped classes should be ignored as possible primary key values in the table.
getImplData() - Method in class org.apache.openjpa.datacache.DataCachePCDataImpl
 
getImplData(int) - Method in class org.apache.openjpa.datacache.DataCachePCDataImpl
 
getImplData() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
getImplData(int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
getImplData() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
getImplData(int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
getImplData() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
getImplData(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
getImplData() - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
An object that concrete back ends can associate with each instance.
getImplData(int) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Field-level impl data.
getImplData() - Method in interface org.apache.openjpa.kernel.PCData
Returns the instance-level impl data, or null if none.
getImplData() - Method in class org.apache.openjpa.kernel.PCDataImpl
 
getImplData(int) - Method in class org.apache.openjpa.kernel.PCDataImpl
 
getImplData() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
getImplData(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
getImplementation(Class, Class) - Method in class org.apache.openjpa.util.StoreFacadeTypeRegistry
Return the implementation for the given facade and store.
getImplementation(Class, Class, Class) - Method in class org.apache.openjpa.util.StoreFacadeTypeRegistry
Return the implementation for the given facade and store.
getImplementorClasses(Class) - Static method in class org.apache.openjpa.lib.util.Services
 
getImplementorClasses(Class, ClassLoader) - Static method in class org.apache.openjpa.lib.util.Services
 
getImplementorClasses(String) - Static method in class org.apache.openjpa.lib.util.Services
Return an array of Class objects of all known service implementors of the specified class name(as resolved by the current thread's context class loader).
getImplementorClasses(String, ClassLoader) - Static method in class org.apache.openjpa.lib.util.Services
 
getImplementorClasses(String, ClassLoader, boolean) - Static method in class org.apache.openjpa.lib.util.Services
Return an array of Class objects of all known service implementors of the specified class name, as resolved by the specified ClassLoader.
getImplementorMappings(Class, ClassLoader, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
 
getImplementorMetaDatas(Class, ClassLoader, boolean) - Method in class org.apache.openjpa.meta.MetaDataRepository
Return all least-derived metadatas with some mapped assignable type that implement the given class.
getImplementors(Class) - Static method in class org.apache.openjpa.lib.util.Services
Return an array of Strings of class names of all known service implementors of the specified interface or class.
getImplementors(Class, ClassLoader) - Static method in class org.apache.openjpa.lib.util.Services
Return an array of Strings of class names of all known service implementors of the specified interface or class.
getImplementors(String) - Static method in class org.apache.openjpa.lib.util.Services
Return an array of Strings of class names of all known service implementors of the specified class name(as resolved by the current thread's context class loader).
getImplementors(String, ClassLoader) - Static method in class org.apache.openjpa.lib.util.Services
Return an array of Strings of class names of all known service implementors of the specified class name, as resolved by the specified ClassLoader.
getImplementsDec(int) - Method in class org.apache.openjpa.lib.util.CodeFormat
Implements declaration.
getImportedKeys(DatabaseMetaData, String, String, String, Connection) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Reflect on the schema to return foreign keys imported by the given table pattern.
getImportedKeys(DatabaseMetaData, String, String, String, Connection) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
getImportedKeys(String, String, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getImportPackages() - Method in class org.apache.openjpa.enhance.ApplicationIdTool
Returns the collection of packages that need to be imported.
getImportPackages() - Method in class org.apache.openjpa.enhance.CodeGenerator
Returns the set of packages that needs to be imported for this code.
getIncrement() - Method in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
 
getIncrement() - Method in class org.apache.openjpa.jdbc.schema.Sequence
The sequence's increment.
getIncrement() - Method in class org.apache.openjpa.kernel.TimeSeededSeq
 
getIncrement() - Method in class org.apache.openjpa.meta.SequenceMetaData
Sequence increment, or -1 for default.
getIndependentAssignableMappings() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Returns the closest-derived list of non-inter-joinable mapped types assignable to this type.
getIndependentElementMappings(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.ContainerFieldStrategy
Return all independent mappings to which this strategy must join in order to access collection elements, or empty array if none.
getIndependentElementMappings(boolean) - Method in interface org.apache.openjpa.jdbc.meta.strats.LRSCollectionFieldStrategy
Return all independent mappings to which this strategy must join in order to access collection elements, or empty array if none.
getIndependentElementMappings(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.MapTableFieldStrategy
 
getIndependentElementMappings(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationCollectionInverseKeyFieldStrategy
 
getIndependentElementMappings(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationCollectionTableFieldStrategy
 
getIndependentElementMappings(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyInverseKeyFieldStrategy
 
getIndependentElementMappings(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyTableFieldStrategy
 
getIndependentExpressionCandidates(ClassMetaData, boolean) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreQuery
 
getIndependentExpressionCandidates(ClassMetaData, boolean) - Method in class org.apache.openjpa.kernel.ExpressionStoreQuery
Return the assignable types for the given metadata whose expression trees must be compiled independently.
getIndependentKeyMappings(boolean) - Method in interface org.apache.openjpa.jdbc.meta.strats.LRSMapFieldStrategy
Return all independent mappings to which this strategy must join in order to access map keys, or empty array if none.
getIndependentKeyMappings(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.MapTableFieldStrategy
 
getIndependentKeyMappings(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapInverseKeyFieldStrategy
 
getIndependentKeyMappings(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapTableFieldStrategy
 
getIndependentTypeMappings() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
getIndependentTypeMappings() - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
Return all independently-mapped joinable types for this value, depending on whether this value is polymorphic and how the related type is mapped.
getIndependentTypeMappings() - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
getIndependentValueMappings(boolean) - Method in interface org.apache.openjpa.jdbc.meta.strats.LRSMapFieldStrategy
Return all independent mappings to which this strategy must join in order to access map values, or empty array if none.
getIndependentValueMappings(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.MapTableFieldStrategy
 
getIndependentValueMappings(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapInverseKeyFieldStrategy
 
getIndependentValueMappings(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapTableFieldStrategy
 
getIndex() - Method in class org.apache.openjpa.jdbc.meta.Discriminator
Index on the Discriminator columns, or null if none.
getIndex(Discriminator, Column[], boolean) - Method in class org.apache.openjpa.jdbc.meta.DiscriminatorMappingInfo
Return the index to set on the discriminator columns, or null if none.
getIndex(ValueMapping, String, Table, Column[]) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Return a default index for the value, or null if the value columns should not be indexed by default.
getIndex(Version, Table, Column[]) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Return a default index for the version, or null if the version columns should not be indexed by default.
getIndex(Discriminator, Table, Column[]) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Return a default index for the discriminator, or null if the discriminator columns should not be indexed by default.
getIndex(ValueMapping, String, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
getIndex(Version, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
getIndex(Discriminator, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
getIndex() - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Raw index.
getIndex(ValueMapping, String, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
getIndex(Version, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
getIndex(Discriminator, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
getIndex(ValueMapping, String, boolean) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingInfo
Return an index for the given columns, or null if none.
getIndex() - Method in class org.apache.openjpa.jdbc.meta.Version
Index on the version columns, or null if none.
getIndex(Version, Column[], boolean) - Method in class org.apache.openjpa.jdbc.meta.VersionMappingInfo
Return the index to set on the version columns, or null if none.
getIndex() - Method in class org.apache.openjpa.jdbc.schema.Column
Return the column's 0-based index in the owning table.
getIndex() - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Return the foreign key's 0-based index in the owning table.
getIndex(String) - Method in class org.apache.openjpa.jdbc.schema.Table
Return the index with the given name, or null if none.
getIndex() - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
The index of this row in ordered row list.
getIndex() - Method in class org.apache.openjpa.meta.FieldMetaData
The absolute index of this persistent/transactional field.
getIndexDiscriminator() - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Whether to index discriminator columns by default.
getIndexes() - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Whether indexes on existing tables should be manipulated.
getIndexes() - Method in class org.apache.openjpa.jdbc.schema.LazySchemaFactory
 
getIndexes() - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Return whether indexes should be generated.
getIndexes() - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Whether indexes on existing tables should be manipulated.
getIndexes() - Method in class org.apache.openjpa.jdbc.schema.Table
Return the table's indexes.
getIndexInfo(DatabaseMetaData, String, String, String, boolean, boolean, Connection) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Reflect on the schema to find indexes matching the given table pattern.
getIndexInfo(DatabaseMetaData, String, String, String, boolean, boolean, Connection) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
getIndexInfo(String, String, String, boolean, boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getIndexLogicalForeignKeys() - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Whether to index logical foreign keys by default.
getIndexName(String, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Generate an index name.
getIndexVersion() - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Whether to index version columns by default.
getInitializer() - Method in class org.apache.openjpa.meta.FieldMetaData
The initializer used by the field, or null if none.
getInitialValue(FieldMetaData) - Method in class org.apache.openjpa.enhance.CodeGenerator
Return code for the initial value for the given field, or null to use the default generated by the system.
getInitialValue() - Method in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
 
getInitialValue(FieldMapping) - Method in class org.apache.openjpa.jdbc.meta.PropertiesReverseCustomizer
 
getInitialValue(FieldMapping) - Method in interface org.apache.openjpa.jdbc.meta.ReverseCustomizer
Return code for the initial value for the given field, or null to use the default generated by the system.
getInitialValue() - Method in class org.apache.openjpa.jdbc.meta.strats.NumberVersionStrategy
Return the initial value for version column.
getInitialValue() - Method in class org.apache.openjpa.jdbc.schema.Sequence
The sequence's initial value.
getInitialValue() - Method in class org.apache.openjpa.meta.SequenceMetaData
Initial sequence value, or -1 for default.
getInnerIdentityClasses() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Whether or not to generate inner classes when creating application identity classes.
getInnermostDelegate() - Method in class org.apache.openjpa.datacache.DelegatingDataCache
Return the native delegate.
getInnermostDelegate() - Method in class org.apache.openjpa.datacache.DelegatingQueryCache
Return the native delegate.
getInnermostDelegate() - Method in class org.apache.openjpa.kernel.DelegatingBroker
Return the native delegate.
getInnermostDelegate() - Method in class org.apache.openjpa.kernel.DelegatingBrokerFactory
Return the native delegate.
getInnermostDelegate() - Method in class org.apache.openjpa.kernel.DelegatingExtent
Return the native delegate.
getInnermostDelegate() - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
Return the native delegate.
getInnermostDelegate() - Method in class org.apache.openjpa.kernel.DelegatingQuery
Return the native delegate.
getInnermostDelegate() - Method in class org.apache.openjpa.kernel.DelegatingResultList.DelegatingListIterator
Return the native delegate.
getInnermostDelegate() - Method in class org.apache.openjpa.kernel.DelegatingResultList
Return the native delegate.
getInnermostDelegate() - Method in class org.apache.openjpa.kernel.DelegatingSeq
Return the native delegate.
getInnermostDelegate() - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
Return the base underlying native store manager.
getInnermostDelegate() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
Return the base underlying data store statement.
getInnermostDelegate() - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
Return the base underlying data store connection.
getInnermostDelegate() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
Return the base underlying database metadata.
getInnermostDelegate() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDataSource
Return the inner-most wrapped delegate.
getInnermostDelegate() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
Return the base underlying data store statement.
getInnermostDelegate() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
Return the inner-most wrapped delegate.
getInnermostDelegate() - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
Return the base underlying data store statement.
getInnermostDelegate() - Method in class org.apache.openjpa.meta.DelegatingMetaDataFactory
Innermost delegate.
getInnermostMappingDelegate() - Method in class org.apache.openjpa.jdbc.meta.MetaDataPlusMappingFactory
Innermost mapping delegate.
getInputStream() - Method in class org.apache.openjpa.lib.meta.ClassMetaDataIterator
 
getInputStream() - Method in class org.apache.openjpa.lib.meta.FileMetaDataIterator
 
getInputStream() - Method in interface org.apache.openjpa.lib.meta.MetaDataIterator
Return the last-iterated metadata resource content as a stream.
getInputStream() - Method in class org.apache.openjpa.lib.meta.MetaDataIteratorChain
 
getInputStream() - Method in class org.apache.openjpa.lib.meta.ResourceMetaDataIterator
 
getInputStream() - Method in class org.apache.openjpa.lib.meta.URLMetaDataIterator
 
getInputStream() - Method in class org.apache.openjpa.lib.meta.ZipFileMetaDataIterator
 
getInputStream() - Method in class org.apache.openjpa.lib.meta.ZipStreamMetaDataIterator
 
getInserts() - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy.CustomUpdate
 
getInserts() - Method in class org.apache.openjpa.jdbc.sql.RowManagerImpl
Return all inserted primary rows.
getInsertTimestamp() - Method in class org.apache.openjpa.lib.util.FormatPreservingProperties
If set to true, this properties object will add a timestamp to the beginning of the file, just after the header (if any) is printed.
getInstance(ConfigurationProvider) - Static method in class org.apache.openjpa.abstractstore.AbstractStoreBrokerFactory
Factory method for obtaining a possibly-pooled BrokerFactory from properties.
getInstance(ConfigurationProvider) - Static method in class org.apache.openjpa.jdbc.kernel.JDBCBrokerFactory
Factory method for obtaining a possibly-pooled factory from properties.
getInstance(JDBCConfiguration) - Static method in class org.apache.openjpa.jdbc.kernel.JDBCBrokerFactory
Factory method for constructing a factory from a configuration.
getInstance() - Static method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
getInstance() - Static method in class org.apache.openjpa.jdbc.meta.strats.BlobValueHandler
Singleton instance.
getInstance() - Static method in class org.apache.openjpa.jdbc.meta.strats.ByteArrayValueHandler
Singleton instance.
getInstance() - Static method in class org.apache.openjpa.jdbc.meta.strats.CharArrayStreamValueHandler
Singleton instance.
getInstance() - Static method in class org.apache.openjpa.jdbc.meta.strats.CharArrayValueHandler
Singleton instance.
getInstance() - Static method in class org.apache.openjpa.jdbc.meta.strats.ClobValueHandler
Singleton instance.
getInstance() - Static method in class org.apache.openjpa.jdbc.meta.strats.ImmutableValueHandler
Singleton instance.
getInstance() - Static method in class org.apache.openjpa.jdbc.meta.strats.NoneClassStrategy
Return the singleton instance.
getInstance() - Static method in class org.apache.openjpa.jdbc.meta.strats.NoneDiscriminatorStrategy
Return singleton instance.
getInstance() - Static method in class org.apache.openjpa.jdbc.meta.strats.NoneFieldStrategy
Return the singleton instance.
getInstance() - Static method in class org.apache.openjpa.jdbc.meta.strats.NoneVersionStrategy
Return singleton instance.
getInstance() - Static method in class org.apache.openjpa.jdbc.meta.strats.UntypedPCValueHandler
Singleton instance.
getInstance() - Static method in class org.apache.openjpa.kernel.UUIDHexSeq
Return the singleton instance.
getInstance() - Static method in class org.apache.openjpa.kernel.UUIDStringSeq
Return the singleton instance.
getInstance() - Static method in class org.apache.openjpa.lib.log.NoneLogFactory.NoneLog
 
getInstance() - Static method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
getInstance(ClassLoader) - Method in class org.apache.openjpa.meta.SequenceMetaData
Return the initialized sequence instance.
getInstantiatingGetter() - Method in class org.apache.openjpa.lib.conf.Value
The name of the getter method for the instantiated value of this property(as opposed to the string value)
getInt(int) - Method in interface org.apache.openjpa.enhance.DynamicStorage
Get the int at the given index.
getInt(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getInt(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getInt(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getInt(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getInt(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getInt(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.PostgresDictionary
 
getInt(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id.
getInt(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column.
getInt(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getInt(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getInt(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getInt(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getIntegrityViolation() - Method in exception org.apache.openjpa.util.ReferentialIntegrityException
The type of integrity violation that occurred.
getInterfaceAliasedProperties(Class) - Method in class org.apache.openjpa.meta.ClassMetaData
Return all aliases property named for the given interface.
getInterfaceImpl() - Method in class org.apache.openjpa.meta.ClassMetaData
Return the managed interface implementor if any.
getInterfacePropertyAlias(Class, String) - Method in class org.apache.openjpa.meta.ClassMetaData
Get local field alias for the given interface property.
getIntermediate(int) - Method in class org.apache.openjpa.datacache.DataCachePCDataImpl
 
getIntermediate(int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
getIntermediate(int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
getIntermediate(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
getIntermediate(int) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Use intermediate field data to store intermediate information that might be available before the field is fully loaded.
getIntermediate(int) - Method in class org.apache.openjpa.kernel.PCDataImpl
 
getIntermediate(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
getInternal(Object) - Method in class org.apache.openjpa.datacache.AbstractDataCache
Return the object for the given oid.
getInternal(QueryKey) - Method in class org.apache.openjpa.datacache.AbstractQueryCache
Return the list for the given key.
getInternal(Object) - Method in class org.apache.openjpa.datacache.ConcurrentDataCache
 
getInternal(QueryKey) - Method in class org.apache.openjpa.datacache.ConcurrentQueryCache
 
getInternal(int) - Method in class org.apache.openjpa.lib.rop.AbstractNonSequentialResultList
Implement this method and List.size().
getInternal(int) - Method in class org.apache.openjpa.lib.rop.RandomAccessResultList
 
getInternal(int) - Method in class org.apache.openjpa.lib.rop.SimpleResultList
 
getInternal(int) - Method in class org.apache.openjpa.lib.rop.WindowResultList
 
getInternalString() - Method in class org.apache.openjpa.lib.conf.BooleanValue
 
getInternalString() - Method in class org.apache.openjpa.lib.conf.DoubleValue
 
getInternalString() - Method in class org.apache.openjpa.lib.conf.FileValue
 
getInternalString() - Method in class org.apache.openjpa.lib.conf.IntValue
 
getInternalString() - Method in class org.apache.openjpa.lib.conf.ObjectValue
 
getInternalString() - Method in class org.apache.openjpa.lib.conf.PluginListValue
 
getInternalString() - Method in class org.apache.openjpa.lib.conf.PluginValue
 
getInternalString() - Method in class org.apache.openjpa.lib.conf.StringListValue
 
getInternalString() - Method in class org.apache.openjpa.lib.conf.StringValue
 
getInternalString() - Method in class org.apache.openjpa.lib.conf.Value
Return the internal string form of this value.
getInterval() - Method in class org.apache.openjpa.datacache.DataCacheScheduler
The interval time in minutes between cache checks.
getIntExtension(String) - Method in class org.apache.openjpa.meta.Extensions
Get the value as an int.
getIntExtension(String, String) - Method in class org.apache.openjpa.meta.Extensions
Get the value as an int.
getIntInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getIntInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getIntProperty(String, String, int) - Method in class org.apache.openjpa.lib.util.Options
Specialization of TypedProperties.getIntProperty(java.lang.String) to allow a value to appear under either of two keys; useful for short and long versions of command-line flags.
getIntProperty(String) - Method in class org.apache.openjpa.lib.util.TypedProperties
Return the property under the given key as an int, or 0 if it does not exist and has no set default.
getIntProperty(String, int) - Method in class org.apache.openjpa.lib.util.TypedProperties
Return the property under the given key as an int, or the given default if it does not exist.
getInverse() - Method in class org.apache.openjpa.meta.FieldMetaData
Logical inverse field.
getInverseManager() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The plugin to use for managing inverse relations.
getInverseManager() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getInverseManager() - Method in interface org.apache.openjpa.kernel.Broker
Return the inverse manager in use.
getInverseManager() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getInverseManager() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getInverseMappings() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Convenience method to perform cast from FieldMetaData.getInverseMetaDatas()
getInverseMetaDatas() - Method in class org.apache.openjpa.meta.FieldMetaData
Return all inverses of this field.
getInverseRelations() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Whether to generate inverse 1-many/1-1 relations for all many-1/1-1 relations.
getInverseTypeJoin(ValueMapping, String, boolean) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingInfo
Return the join from the related type to this value.
getJarFileUrls() - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
getJavaType() - Method in class org.apache.openjpa.jdbc.meta.strats.ClassNameDiscriminatorStrategy
 
getJavaType() - Method in class org.apache.openjpa.jdbc.meta.strats.ColumnVersionStrategy
Return the code from JavaTypes for the version values this strategy uses.
getJavaType() - Method in class org.apache.openjpa.jdbc.meta.strats.InValueDiscriminatorStrategy
Return the Java type code from JavaTypes for the discriminator values.
getJavaType() - Method in class org.apache.openjpa.jdbc.meta.strats.NumberVersionStrategy
 
getJavaType() - Method in class org.apache.openjpa.jdbc.meta.strats.TimestampVersionStrategy
 
getJavaType() - Method in class org.apache.openjpa.jdbc.meta.strats.ValueMapDiscriminatorStrategy
 
getJavaType() - Method in class org.apache.openjpa.jdbc.schema.Column
The Java type the data in this column is treated as, from JavaTypes or JavaSQLTypes.
getJavaType(int, int, int) - Static method in class org.apache.openjpa.jdbc.schema.Schemas
Return the java type for the given SQL type from Types.
getJDBCDelegate() - Method in class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
Return the JDBC delegate.
getJDBCListenerInstances() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The JDBCListeners to use.
getJDBCListenerInstances() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getJDBCListeners() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
A comma-separated list of the JDBCListener plugins for listening to JDBCEvents.
getJDBCListeners() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getJDBCLog() - Method in class org.apache.openjpa.lib.jdbc.DataSourceLogs
The log to write JDBC messages to.
getJDBCMajorVersion() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getJDBCMinorVersion() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getJDBCName(int) - Static method in class org.apache.openjpa.jdbc.schema.Schemas
Return the SQL type name for the given Types constant.
getJDBCType(String) - Static method in class org.apache.openjpa.jdbc.schema.Schemas
Return the Types constant for the given SQL type name.
getJDBCType(int, boolean) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return the preferred Types constant for the given JavaTypes or JavaSQLTypes constant.
getJDBCType(int, boolean) - Method in class org.apache.openjpa.jdbc.sql.HSQLDictionary
 
getJDBCType(int, boolean) - Method in class org.apache.openjpa.jdbc.sql.SybaseDictionary
 
getJoin(FieldMapping, Table, boolean) - Method in class org.apache.openjpa.jdbc.meta.FieldMappingInfo
Return the join from the field table to the owning class table.
getJoinable(Column) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Return the Joinable for the given column.
getJoinablePCSubclassMappings() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Return mapped subclasses that are reachable via joins.
getJoinablePCSuperclassMapping() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Return the nearest mapped superclass that can join to this class.
getJoinColumnIO() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
I/O information on the join columns.
getJoinDirection() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
getJoinDirection() - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Direction of the join that the columns of this mapping info form.
getJoinDirection() - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
The join direction.
getJoinDirection() - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
getJoinForeignKey() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Foreign key linking the primary key columns to the superclass table, or null if none.
getJoinForeignKey() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Foreign key linking the field table to the class' primary table.
getJoinForeignKey(ClassMapping, Table, Table) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Return a default foreign key for the join from this class' table to its superclass' table, or null for a logical foreign key only.
getJoinForeignKey(FieldMapping, Table, Table) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Return a default foreign key for the join from this field's table to its defining class' table, or null for a logical foreign key only.
getJoinForeignKey(ClassMapping, Table, Table) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
getJoinForeignKey(FieldMapping, Table, Table) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
getJoinForeignKey(ClassMapping, Table, Table) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
getJoinForeignKey(FieldMapping, Table, Table) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
getJoinForeignKey() - Method in class org.apache.openjpa.jdbc.meta.strats.ContainerFieldStrategy
 
getJoinForeignKey(ClassMapping) - Method in interface org.apache.openjpa.jdbc.meta.strats.LRSCollectionFieldStrategy
Return the foreign key used to join to the owning field for the given element mapping from LRSCollectionFieldStrategy.getIndependentElementMappings(boolean) (or null).
getJoinForeignKey(ClassMapping) - Method in interface org.apache.openjpa.jdbc.meta.strats.LRSMapFieldStrategy
Return the foreign key used to join to the owning field for the given mapping from either LRSMapFieldStrategy.getIndependentKeyMappings(boolean) or LRSMapFieldStrategy.getIndependentValueMappings(boolean) (or null).
getJoinForeignKey(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.MapTableFieldStrategy
 
getJoinForeignKey() - Method in class org.apache.openjpa.jdbc.meta.strats.MapTableFieldStrategy
 
getJoinForeignKey(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationCollectionInverseKeyFieldStrategy
 
getJoinForeignKey(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationCollectionTableFieldStrategy
 
getJoinForeignKey(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapInverseKeyFieldStrategy
 
getJoinForeignKey(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapTableFieldStrategy
 
getJoinForeignKey(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyInverseKeyFieldStrategy
 
getJoinForeignKey(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyTableFieldStrategy
 
getJoinForeignKey(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.StoreCollectionFieldStrategy
Return the foreign key used to join to the owning field for the given element mapping from ContainerFieldStrategy.getIndependentElementMappings(boolean) (or null).
getJoinForeignKey() - Method in class org.apache.openjpa.jdbc.meta.strats.StoreCollectionFieldStrategy
 
getJoinForeignKeyDeleteAction() - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default foreign key action for join keys.
getJoinIndex() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Index on join foreign key columns.
getJoinIndex(FieldMapping, boolean) - Method in class org.apache.openjpa.jdbc.meta.FieldMappingInfo
Index on the field join.
getJoinIndex(FieldMapping, Table, Column[]) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Return a default index for the join, or null if the join columns should not be indexed by default.
getJoinIndex(FieldMapping, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
getJoinIndex(FieldMapping, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
getJoinIterator() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getJoinIterator() - Method in interface org.apache.openjpa.jdbc.sql.Select
Return the top-level Join elements for this select.
getJoinIterator() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getJoins() - Method in class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
 
getJoins() - Method in interface org.apache.openjpa.jdbc.kernel.JDBCFetchConfiguration
Returns the names of the joins that this component will use when loading objects.
getJoins() - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
getJoins() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getJoins() - Method in interface org.apache.openjpa.jdbc.sql.Select
Return the top-level joins for this select.
getJoins() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getJoinSyntax() - Method in class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
 
getJoinSyntax() - Method in interface org.apache.openjpa.jdbc.kernel.JDBCFetchConfiguration
The join syntax to use.
getJoinSyntax() - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
getJoinSyntax() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
getJoinSyntax() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getJoinSyntax() - Method in interface org.apache.openjpa.jdbc.sql.SelectExecutor
The join syntax for this select, as one of the syntax constants from JoinSyntaxes.
getJoinSyntax() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getJoinSyntax() - Method in interface org.apache.openjpa.persistence.jdbc.JDBCFetchPlan
SQL join syntax.
getJoinSyntax() - Method in class org.apache.openjpa.persistence.jdbc.JDBCFetchPlanImpl
 
getJoinUnique() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Unique constraint on join foreign key columns.
getJoinUnique(FieldMapping, boolean, boolean) - Method in class org.apache.openjpa.jdbc.meta.FieldMappingInfo
Unique constraint on the field join.
getJoinUnique(FieldMapping, Table, Column[]) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Return a default constraint for the join, or null if the join columns should not be constrained by default.
getJoinUnique(FieldMapping, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
getJoinUnique(FieldMapping, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
getJoinValue(Object, Column, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.DelegatingJoinable
 
getJoinValue(OpenJPAStateManager, Column, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.DelegatingJoinable
 
getJoinValue(Object, Column, JDBCStore) - Method in interface org.apache.openjpa.jdbc.meta.Joinable
Return the join value of the given column.
getJoinValue(OpenJPAStateManager, Column, JDBCStore) - Method in interface org.apache.openjpa.jdbc.meta.Joinable
Return the join value of the given column.
getJoinValue(Object, Column, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
getJoinValue(OpenJPAStateManager, Column, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
getJoinValue(Object, Column, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
getJoinValue(OpenJPAStateManager, Column, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
getJoinValue(Object, Column, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
getJoinValue(OpenJPAStateManager, Column, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
getJoinValue(Object, Column, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
getJoinValue(OpenJPAStateManager, Column, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
getJtaDataSource() - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
getJtaDataSourceName() - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
getKey() - Method in class org.apache.openjpa.datacache.ExpirationEvent
Return the expired object id or query key.
getKey() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap.Entry
 
getKey() - Method in class org.apache.openjpa.lib.util.Localizer.Message
The unique key for the localized message.
getKey() - Method in class org.apache.openjpa.meta.FieldMetaData
Metadata about the key value.
getKeyColumns(ClassMapping) - Method in interface org.apache.openjpa.jdbc.meta.strats.LRSMapFieldStrategy
Return the columns holding data for a map key for the given key mapping from LRSMapFieldStrategy.getIndependentKeyMappings(boolean) or LRSMapFieldStrategy.getIndependentValueMappings(boolean) (or null).
getKeyColumns(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapInverseKeyFieldStrategy
 
getKeyColumns(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapTableFieldStrategy
 
getKeyMapping() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Convenience method to perform cast from FieldMetaData.getKey()
getKeySequence() - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
The sequence of this join in the foreign key.
getLanguage() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getLanguage() - Method in interface org.apache.openjpa.kernel.exps.ExpressionParser
Return a string key describing the language that this instance parses.
getLanguage() - Method in class org.apache.openjpa.kernel.jpql.JPQLParser
 
getLanguage() - Method in interface org.apache.openjpa.kernel.QueryContext
The query language.
getLanguage() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getLanguage() - Method in class org.apache.openjpa.meta.QueryMetaData
Return the query language.
getLanguage() - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Query language.
getLanguage() - Method in class org.apache.openjpa.persistence.QueryImpl
 
getLength() - Method in class org.apache.openjpa.lib.util.concurrent.WaitQueue
 
getLevel() - Method in class org.apache.openjpa.event.LogOrphanedKeyAction
The level to log at.
getLevel(String) - Static method in class org.apache.openjpa.lib.log.LogFactoryImpl
Returns a symbolic constant for the specified string level.
getLevel() - Method in class org.apache.openjpa.lib.log.LogFactoryImpl.LogImpl
 
getLevelName(short) - Static method in class org.apache.openjpa.lib.log.LogFactoryImpl
Returns a string representation of the specified log level constant.
getLevenshteinDistance(String, String) - Static method in class org.apache.openjpa.lib.util.StringDistance
Returns the Levenshtein distance between the two strings.
getLexicalHandler() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
The lexical handler that should be registered with the SAX parser used by this class.
getLifecycleEventManager() - Method in interface org.apache.openjpa.kernel.Broker
Return the lifecycle event manager associated with the broker.
getLifecycleEventManager() - Method in class org.apache.openjpa.kernel.BrokerImpl
Give state managers access to the lifecycle event manager.
getLifecycleEventManager() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getLifecycleListenerCallbackMode() - Method in interface org.apache.openjpa.kernel.Broker
The callback mode for handling exceptions from lifecycle event listeners.
getLifecycleListenerCallbackMode() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getLifecycleListenerCallbackMode() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getLifecycleListenerCallbackMode() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getLifecycleListenerCallbackMode() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
The CallbackModes flags for handling lifecycle listener exceptions.
getLifecycleMetaData() - Method in class org.apache.openjpa.meta.ClassMetaData
Information about lifecycle callbacks for this class.
getLineLength() - Method in class org.apache.openjpa.lib.jdbc.SQLFormatter
 
getLinesBetweenSections() - Method in class org.apache.openjpa.lib.util.CodeFormat
The number of empty lines between code sections.
getListener() - Method in class org.apache.openjpa.lib.conf.Value
Listener for value changes.
getListeners() - Method in class org.apache.openjpa.lib.util.AbstractEventManager
Return a read-only list of listeners.
getListeners() - Method in class org.apache.openjpa.lib.util.concurrent.AbstractConcurrentEventManager
Return a read-only list of listeners.
getListeners() - Method in interface org.apache.openjpa.lib.util.EventManager
Return a read-only list of listeners.
getListingIndex() - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping
Relative order of result mapping in metadata.
getListingIndex() - Method in class org.apache.openjpa.meta.ClassMetaData
The index in which this class was listed in the metadata.
getListingIndex() - Method in class org.apache.openjpa.meta.FieldMetaData
The index in which this field was listed in the metadata.
getListingIndex() - Method in class org.apache.openjpa.meta.NonPersistentMetaData
The index in which this class was listed in the metadata.
getLoaded() - Method in class org.apache.openjpa.kernel.AbstractPCData
Return the loaded field mask.
getLoaded() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
getLoaded() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
getLoaded() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
getLoaded() - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return a read-only mask of the indexes of all loaded fields.
getLoaded() - Method in class org.apache.openjpa.kernel.PCDataImpl
 
getLoaded() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
getLoaded(Object[]) - Static method in class org.apache.openjpa.util.ArrayStateImage
Get the loaded mask from a state image.
getLoadFetchGroup() - Method in class org.apache.openjpa.meta.FieldMetaData
The fetch group that is to be loaded when this receiver is loaded, or null if none set.
getLoadKey() - Method in class org.apache.openjpa.lib.conf.Value
The key under which this value was loaded, or null.
getLocale(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getLocale(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getLocale(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getLocale(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getLocale(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getLocale(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id.
getLocale(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column.
getLocaleInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getLocaleInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getLocalizer() - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
Used for obtaining the Localizer to use for translating error messages.
getLocalTransaction() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getLocalTransaction() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getLocalTransaction() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getLocation() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
The XML document location.
getLocation(String) - Method in class org.apache.openjpa.lib.xml.Location
for customized responses
getLocation() - Method in class org.apache.openjpa.lib.xml.Location
 
getLocator() - Method in class org.apache.openjpa.lib.xml.Location
 
getLock() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
getLock() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
getLock() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
getLock() - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
The lock object set for this instance.
getLock() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
getLockLevel(Object) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getLockLevel(Object) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getLockLevel(OpenJPAStateManager) - Method in interface org.apache.openjpa.kernel.LockManager
Return the lock level of the specified instance, or LockLevels.LOCK_NONE if not locked.
getLockLevel(OpenJPAStateManager) - Method in class org.apache.openjpa.kernel.NoneLockManager
 
getLockLevel(Object) - Method in interface org.apache.openjpa.kernel.StoreContext
Return the lock level of the specified object.
getLockLevel(OpenJPAStateManager) - Method in class org.apache.openjpa.kernel.VersionLockManager
Returns the given instance's lock level, assuming that the state's lock object is a number.
getLockManager() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The plugin to use for datastore lock management.
getLockManager() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getLockManager() - Method in interface org.apache.openjpa.jdbc.kernel.JDBCStore
If the lock manager in use is a JDBCLockManager, return it.
getLockManager() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
getLockManager() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getLockManager() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getLockManager() - Method in interface org.apache.openjpa.kernel.StoreContext
Return the lock manager in use.
getLockMode(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getLockMode(Object) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return the lock mode of the given instance, or null if not locked.
getLockTimeout() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The time to wait for an object lock in milliseconds, or -1 for no timeout.
getLockTimeout() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getLockTimeout() - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
getLockTimeout() - Method in interface org.apache.openjpa.kernel.FetchConfiguration
The number of milliseconds to wait for an object lock, or -1 for no limit.
getLockTimeout() - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
getLockTimeout() - Method in interface org.apache.openjpa.persistence.FetchPlan
The number of milliseconds to wait for an object lock, or -1 for no limit.
getLockTimeout() - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
getLog() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Return the log to write to.
getLog() - Method in interface org.apache.openjpa.lib.conf.Configuration
Log plugin setting.
getLog(String) - Method in interface org.apache.openjpa.lib.conf.Configuration
Return the log for the given category.
getLog() - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
getLog(String) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
getLog(String) - Method in interface org.apache.openjpa.lib.log.LogFactory
Return a log for the given channel name.
getLog(String) - Method in class org.apache.openjpa.lib.log.LogFactoryAdapter
 
getLog(String) - Method in class org.apache.openjpa.lib.log.LogFactoryImpl
 
getLog(String) - Method in class org.apache.openjpa.lib.log.MultiLogFactory
Returns a Log impl that combines all logs.
getLog(String) - Method in class org.apache.openjpa.lib.log.NoneLogFactory
 
getLog() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
The log to write to.
getLog() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
The log to write to.
getLog() - Method in class org.apache.openjpa.meta.MetaDataRepository
Return the metadata log.
getLog() - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Metadata log.
getLogFactory() - Method in interface org.apache.openjpa.lib.conf.Configuration
The log factory.
getLogFactory() - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
getLoginTimeout() - Method in class org.apache.openjpa.jdbc.schema.SimpleDriverDataSource
 
getLoginTimeout() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDataSource
 
getLogs() - Method in class org.apache.openjpa.lib.jdbc.LoggingConnectionDecorator
The log to write to.
getLogWriter() - Method in class org.apache.openjpa.jdbc.schema.SimpleDriverDataSource
 
getLogWriter() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDataSource
 
getLong(int) - Method in interface org.apache.openjpa.enhance.DynamicStorage
Get the long at the given index.
getLong(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getLong(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getLong(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getLong(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getLong(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getLong(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.PostgresDictionary
 
getLong(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id.
getLong(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column.
getLong(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getLong(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getLong(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getLong(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getLongInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getLongInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getLongProperty(String, String, long) - Method in class org.apache.openjpa.lib.util.Options
Specialization of TypedProperties.getLongProperty(java.lang.String) to allow a value to appear under either of two keys; useful for short and long versions of command-line flags.
getLongProperty(String) - Method in class org.apache.openjpa.lib.util.TypedProperties
Return the property under the given key as a long, or 0 if it does not exist and has no set default.
getLongProperty(String, long) - Method in class org.apache.openjpa.lib.util.TypedProperties
Return the property under the given key as a double, or the given default if it does not exist.
getLRSSize() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
How to obtain the size of large result sets.
getLRSSize() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getLRSSize() - Method in class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
 
getLRSSize() - Method in interface org.apache.openjpa.jdbc.kernel.JDBCFetchConfiguration
The large result set size mode to use.
getLRSSize() - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
getLRSSize() - Method in interface org.apache.openjpa.persistence.jdbc.JDBCFetchPlan
How to determine the size of a large result set.
getLRSSize() - Method in class org.apache.openjpa.persistence.jdbc.JDBCFetchPlanImpl
 
getLRSSizeConstant() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Return the LRSSizes constant for the large result set size setting.
getLRSSizeConstant() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getManagedClassNames() - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
getManagedInstance() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
getManagedInstance() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
getManagedInstance() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
getManagedInstance() - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return the managed instance.
getManagedInstance() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
getManagedObjects() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getManagedObjects() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getManagedObjects() - Method in interface org.apache.openjpa.kernel.StoreContext
Return a list of all managed instances.
getManagedObjects() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getManagedObjects() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return a set of all managed instances.
getManagedRuntime() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The plugin string for the ManagedRuntime to use for managed environments.
getManagedRuntime() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getManagedRuntime() - Method in interface org.apache.openjpa.kernel.Broker
Return the managed runtime in use.
getManagedRuntime() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getManagedRuntime() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getManagedRuntime() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getManagedRuntime() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return the managed runtime in use.
getManagedRuntimeInstance() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The plugin to use for integrating with a managed runtime.
getManagedRuntimeInstance() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getManagedStates() - Method in class org.apache.openjpa.kernel.BrokerImpl
Return a copy of all managed state managers.
getManagedType(Object) - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
 
getManagedType(Object) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
getManagedType(Object) - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
getManagedType(Object) - Method in interface org.apache.openjpa.kernel.StoreManager
Return the persistent class for the given data store identity value.
getManageLRS() - Method in class org.apache.openjpa.kernel.InverseManager
Return whether to manage LRS fields.
getManagement() - Method in class org.apache.openjpa.meta.FieldMetaData
Return the management level for the field.
getMappedBy() - Method in class org.apache.openjpa.meta.FieldMetaData
The field that this field shares a mapping with.
getMappedByMapping() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Convenience method to perform cast from FieldMetaData.getMappedByMetaData()
getMappedByMetaData() - Method in class org.apache.openjpa.meta.FieldMetaData
The field that this field shares a mapping with.
getMappedPCSubclassMappings() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Convenience method to perform cast from ClassMetaData.getMappedPCSubclassMetaDatas().
getMappedPCSubclassMetaDatas() - Method in class org.apache.openjpa.meta.ClassMetaData
Return all mapped subclasses.
getMappedPCSuperclassMapping() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Convenience method to perform cast from ClassMetaData.getMappedPCSuperclassMetaData().
getMappedPCSuperclassMetaData() - Method in class org.apache.openjpa.meta.ClassMetaData
Return the closest mapped superclass.
getMapping() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The name mapping to use for this data store.
getMapping() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getMapping(Class, ClassLoader, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
 
getMapping(Object, ClassLoader, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
 
getMapping(String) - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping.PCResult
Return the mapping id for the given path supplied with QueryResultMapping.PCResult.addMapping(java.lang.String, java.lang.Object), or null if none.
getMappingDefaults() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
A plugin string describing the MappingDefaults to use.
getMappingDefaults() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getMappingDefaults() - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Mapping defaults.
getMappingDefaultsInstance() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The MappingDefaults to use with a repository.
getMappingDefaultsInstance() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getMappingDelegate() - Method in class org.apache.openjpa.jdbc.meta.MetaDataPlusMappingFactory
Mapping factory delegate.
getMappingFactory() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
A plugin string describing the MetaDataFactory to use for loading and storing object-relational mapping data.
getMappingFactory() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getMappingFile() - Method in class org.apache.openjpa.jdbc.meta.SequenceMapping
Allow sequence to have a mapping file separate from its metadata source file.
getMappingFileNames() - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
getMappingInfo() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Raw mapping data.
getMappingInfo() - Method in class org.apache.openjpa.jdbc.meta.Discriminator
Raw mapping data.
getMappingInfo() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Raw mapping data about field's join to parent table, as well as miscellaneous specialized columns like order column.
getMappingInfo() - Method in class org.apache.openjpa.jdbc.meta.Version
Raw mapping data.
getMappingOverride() - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Whether to allow later parses of mapping information to override earlier information for the same class.
getMappingOverride() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Whether to allow later parses of mapping information to override earlier information for the same class.
getMappingPaths() - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping.PCResult
Return the raw mapping paths supplied with QueryResultMapping.PCResult.addMapping(java.lang.String, java.lang.Object), or empty array if none.
getMappingRepository() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Convenience method to perform cast from ClassMetaData.getRepository().
getMappingRepository() - Method in class org.apache.openjpa.jdbc.meta.Discriminator
 
getMappingRepository() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Convenience method to perform cast from FieldMetaData.getRepository()
getMappingRepository() - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
Convenience method to perform cast from MetaDataContext.getRepository().
getMappingRepository() - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
getMappingRepository() - Method in class org.apache.openjpa.jdbc.meta.Version
 
getMappingRepositoryInstance() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Return the mapping repository.
getMappingRepositoryInstance() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getMappings() - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
 
getMappings() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Return the generated mappings.
getMappingWriter() - Method in class org.apache.openjpa.jdbc.meta.MappingTool
The stream to export the planned mappings to as an XML document.
getMapValue(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
getMapValue(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return an expression representing the given condition.
getMapValue(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
getMaxActive() - Method in class org.apache.openjpa.event.TCPRemoteCommitProvider
The maximum number of sockets that this provider can simetaneously open to each peer in the cluster.
getMaxBinaryLiteralLength() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getMaxCatalogNameLength() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getMaxCharLiteralLength() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getMaxColumnNameLength() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getMaxColumnsInGroupBy() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getMaxColumnsInIndex() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getMaxColumnsInOrderBy() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getMaxColumnsInSelect() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getMaxColumnsInTable() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getMaxConnections() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getMaxCursorNameLength() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getMaxFetchDepth() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The maximum relation depth to traverse when eager fetching.
getMaxFetchDepth() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getMaxFetchDepth() - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
getMaxFetchDepth() - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Return the maximum depth of fetched instance graph.
getMaxFetchDepth() - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
getMaxFetchDepth() - Method in interface org.apache.openjpa.persistence.FetchPlan
The maximum fetch depth when loading an object.
getMaxFetchDepth() - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
getMaxFieldSize() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getMaxFieldSize() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
getMaxFieldSize() - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
getMaxIdle() - Method in class org.apache.openjpa.event.TCPRemoteCommitProvider
The number of idle sockets that this provider can keep open to each peer in the cluster.
getMaxIndexLength() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getMaxProcedureNameLength() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getMaxResults() - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Return the maximum number of results to retrieve.
getMaxResults() - Method in class org.apache.openjpa.persistence.QueryImpl
 
getMaxRows() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getMaxRows() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
getMaxRows() - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
getMaxRowSize() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getMaxSchemaNameLength() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getMaxSize() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
 
getMaxSize() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
 
getMaxSize() - Method in class org.apache.openjpa.lib.util.LRUMap
 
getMaxSize() - Method in class org.apache.openjpa.lib.util.ReferenceHashMap
 
getMaxSize() - Method in interface org.apache.openjpa.lib.util.SizedMap
The maximum number of entries, or Integer.MAX_VALUE for no limit.
getMaxStatementLength() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getMaxStatements() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getMaxTableNameLength() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getMaxTablesInSelect() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getMaxUserNameLength() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getMessage() - Method in class org.apache.openjpa.lib.util.Localizer.Message
The localized message.
getMessage() - Method in interface org.apache.openjpa.util.ExceptionInfo
Exception message.
getMessageListener() - Method in class org.apache.openjpa.event.JMSRemoteCommitProvider
 
getMetaData() - Method in class org.apache.openjpa.enhance.ApplicationIdTool
Return metadata for the type we are generating an application id for.
getMetaData() - Method in class org.apache.openjpa.enhance.CodeGenerator
Return metadata for the type being generated.
getMetaData() - Method in class org.apache.openjpa.enhance.PCEnhancer
Return the metadata for the class being manipulated, or null if not a persistent type.
getMetaData() - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
 
getMetaData() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getMetaData() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getMetaData() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
getMetaData() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
getMetaData(Class, boolean) - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
Convenience method to get metadata for the given type.
getMetaData(Class, boolean, ClassLoader) - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
Convenience method to get metadata for the given type.
getMetaData() - Method in class org.apache.openjpa.kernel.exps.Val
 
getMetaData() - Method in interface org.apache.openjpa.kernel.exps.Value
Return any associated persistent type.
getMetaData() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
getMetaData() - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Get the metadata for this instance.
getMetaData() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
getMetaData() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getMetaData() - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
getMetaData(boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
Return the metadata, with the option of not wrapping it in a DelegatingDatabaseMetaData, which is the default.
getMetaData() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
getMetaData() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getMetaData(Class, ClassLoader, boolean) - Method in class org.apache.openjpa.meta.MetaDataRepository
Return the metadata for the given class.
getMetaData(String, ClassLoader, boolean) - Method in class org.apache.openjpa.meta.MetaDataRepository
Return the metadata for the given alias name.
getMetaData(Object, ClassLoader, boolean) - Method in class org.apache.openjpa.meta.MetaDataRepository
Return the least-derived class metadata for the given application identity object.
getMetaData() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getMetaData(Object) - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
Returns the ClassMetaData associated with the persistent object o.
getMetaData(EntityManager, Class) - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
Returns the ClassMetaData associated with the persistent type cls.
getMetaData(EntityManagerFactory, Class) - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
Returns the ClassMetaData associated with the persistent type cls.
getMetaData() - Method in class org.apache.openjpa.xmlstore.ObjectData
Get the metadata associated with the type of persistent object for which this data applies.
getMetaDataFactory() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
A plugin string describing the MetaDataFactory to use.
getMetaDataFactory() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getMetaDataFactory() - Method in class org.apache.openjpa.meta.MetaDataRepository
The I/O used to load metadata.
getMetaDataFile() - Method in class org.apache.openjpa.jdbc.meta.MappingTool
If adding metadata, the metadata file to add to.
getMetaDataRepository() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
A plugin string describing the MetaDataRepository to use.
getMetaDataRepository() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getMetaDataRepositoryInstance() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The metadata repository of managed class information.
getMetaDataRepositoryInstance() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getMetaDatas() - Method in class org.apache.openjpa.meta.MetaDataRepository
Return all the metadata instances currently in the repository.
getMethod(Class, String, Class[]) - Static method in class org.apache.openjpa.event.MethodLifecycleCallbacks
Helper method to return the named method of the given class, throwing the proper exception on error.
getMethodDescriptors() - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
getMode() - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
The parse mode.
getMode() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
The parse mode according to the expected document type.
getMode() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
The serialization mode according to the expected document type.
getMoreResults() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getMoreResults(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getMoreResults() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
getMoreResults(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
getMoreResults() - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
getMoreResults(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
getMultiLine() - Method in class org.apache.openjpa.lib.jdbc.SQLFormatter
If true, then try to parse multi-line SQL statements.
getMultithreaded() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Whether brokers or their managed objects will be used by multiple concurrent threads.
getMultithreaded() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getMultithreaded() - Method in interface org.apache.openjpa.kernel.Broker
Whether the broker or its managed instances are used in a multithreaded environment.
getMultithreaded() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getMultithreaded() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getMultithreaded() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getMultithreaded() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether the entity manager or its managed instances are used in a multithreaded environment.
getName() - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
getName() - Method in interface org.apache.openjpa.datacache.DataCache
Returns a string name that can be used by end-user-visible code to identify this cache.
getName() - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
getName() - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping
Return the name for this query result.
getName() - Method in class org.apache.openjpa.jdbc.schema.Column
Return the column's name.
getName() - Method in class org.apache.openjpa.jdbc.schema.Constraint
Return the name of the constraint.
getName() - Method in class org.apache.openjpa.jdbc.schema.Schema
Return the name of the schema, or null if none.
getName() - Method in class org.apache.openjpa.jdbc.schema.Sequence
Return the name of the sequence.
getName() - Method in class org.apache.openjpa.jdbc.schema.Table
Return the name of the table.
getName() - Method in class org.apache.openjpa.kernel.OpenJPASavepoint
Return the name for this savepoint.
getName() - Method in interface org.apache.openjpa.lib.meta.MetaDataFilter.Resource
The name of the resource.
getName() - Method in class org.apache.openjpa.lib.meta.ZipFileMetaDataIterator
 
getName() - Method in class org.apache.openjpa.lib.meta.ZipStreamMetaDataIterator
 
getName() - Method in class org.apache.openjpa.meta.FetchGroup
Fetch group name.
getName() - Method in class org.apache.openjpa.meta.FieldMetaData
The field name.
getName() - Method in interface org.apache.openjpa.meta.Order
Return the name of the orderable.
getName() - Method in class org.apache.openjpa.meta.QueryMetaData
Return the name for this query.
getName() - Method in class org.apache.openjpa.meta.SequenceMetaData
The sequence name.
getName(int) - Static method in class org.apache.openjpa.meta.UpdateStrategies
Convert the given strategy to a name.
getName(int) - Static method in class org.apache.openjpa.meta.ValueStrategies
Convert the given strategy to a name.
getName() - Method in interface org.apache.openjpa.persistence.Generator
The sequence name.
getName() - Method in class org.apache.openjpa.persistence.GeneratorImpl
 
getNamedGenerator(String) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getNamedGenerator(String) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return the named generator defined in the metadata.
getNamedParameters() - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
The named parameters for the query; empty map if none or if query uses named parameters.
getNamedParameters() - Method in class org.apache.openjpa.persistence.QueryImpl
 
getNestedThrowables() - Method in exception org.apache.openjpa.persistence.ArgumentException
 
getNestedThrowables() - Method in exception org.apache.openjpa.persistence.EntityExistsException
 
getNestedThrowables() - Method in exception org.apache.openjpa.persistence.EntityNotFoundException
 
getNestedThrowables() - Method in exception org.apache.openjpa.persistence.InvalidStateException
 
getNestedThrowables() - Method in exception org.apache.openjpa.persistence.NonUniqueResultException
 
getNestedThrowables() - Method in exception org.apache.openjpa.persistence.NoResultException
 
getNestedThrowables() - Method in exception org.apache.openjpa.persistence.OptimisticLockException
 
getNestedThrowables() - Method in exception org.apache.openjpa.persistence.PersistenceException
 
getNestedThrowables() - Method in exception org.apache.openjpa.persistence.RollbackException
 
getNestedThrowables() - Method in exception org.apache.openjpa.persistence.TransactionRequiredException
 
getNestedThrowables() - Method in interface org.apache.openjpa.util.ExceptionInfo
The nested throwables.
getNestedThrowables() - Method in exception org.apache.openjpa.util.OpenJPAException
The nested throwables.
getNewline() - Method in class org.apache.openjpa.lib.jdbc.SQLFormatter
 
getNewTableSchema(JDBCConfiguration) - Static method in class org.apache.openjpa.jdbc.schema.Schemas
Return the schema name that should be used for new tables, or null if none.
getNewTempClassLoader() - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
getNextSequence() - Method in class org.apache.openjpa.util.AbstractChangeTracker
 
getNextSequence() - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
getNextSequence() - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
getNextSequence() - Method in interface org.apache.openjpa.util.ChangeTracker
The next element sequence value for this proxy at load time.
getNonEmptyValue(int) - Static method in class org.apache.openjpa.jdbc.meta.JavaSQLTypes
Return a non-empty value object for the given type code.
getNonJtaDataSource() - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
getNonJtaDataSourceName() - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
getNonMappedInterface(Class) - Method in class org.apache.openjpa.meta.MetaDataRepository
Gets the metadata corresponding to the given non-mapped interface.
getNonMappedInterfaces() - Method in class org.apache.openjpa.meta.MetaDataRepository
Gets the corresponding metadatas for all registered, non-mapped interfaces
getNonOptimisticVersionCheck() - Method in class org.apache.openjpa.conf.Compatibility
Whether or not to perform a version check on instances being updated in a datastore transaction.
getNonPCSuperclassCallbacks(int) - Method in class org.apache.openjpa.meta.LifecycleMetaData
Return the callbacks for the non-PC superclass.
getNontransactionalRead() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Whether persistent state is accessible outside a transaction by default.
getNontransactionalRead() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getNontransactionalRead() - Method in interface org.apache.openjpa.kernel.Broker
Whether to allow nontransactional access to persistent state.
getNontransactionalRead() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getNontransactionalRead() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getNontransactionalRead() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getNontransactionalRead() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether to allow nontransactional access to persistent state.
getNontransactionalWrite() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Whether persistent state can be modified outside a transaction by default.
getNontransactionalWrite() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getNontransactionalWrite() - Method in interface org.apache.openjpa.kernel.Broker
Whether to allow nontransactional changes to persistent state.
getNontransactionalWrite() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getNontransactionalWrite() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getNontransactionalWrite() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getNontransactionalWrite() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether to allow nontransactional changes to persistent state.
getNull() - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
getNull() - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return a value representing null.
getNull() - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
getNullableAsObject() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Return whether even nullable columns will be mapped to wrappers rather than primitives.
getNullIndicatorColumn(ValueMapping, String, Table, boolean) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingInfo
Return the null indicator column for this value, or null if none.
getNullIndicatorColumnName() - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default base name for null indicator columns, or null to the mapping's built-in name.
getNullIndicatorValue(OpenJPAStateManager) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbeddedClassStrategy
Return the proper synthetic null indicator value for the given instance.
getNullValue() - Method in class org.apache.openjpa.meta.FieldMetaData
How the data store should treat null values for this field: FieldMetaData.NULL_UNSET: no value supplied FieldMetaData.NULL_NONE: leave null values as null in the data store FieldMetaData.NULL_EXCEPTION: throw an exception if this field is null at commit FieldMetaData.NULL_DEFAULT: use the database default if this field is null at commit Defaults to FieldMetaData.NULL_UNSET.
getNumber(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getNumber(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getNumber(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Returns the specified column value as an unknown numeric type; we try from the most generic to the least generic.
getNumber(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getNumber(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getNumber(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id.
getNumber(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column.
getNumberInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getNumberInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getNumBroadcastThreads() - Method in class org.apache.openjpa.event.TCPRemoteCommitProvider
The number of worker threads that are used for transmitting packets to peers in the cluster.
getNumericFunctions() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getObject(int) - Method in interface org.apache.openjpa.enhance.DynamicStorage
Get the object at the given index.
getObject(Object, int, Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getObject(Column, Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getObject(ResultSet, int, Map) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getObject(Object, int, Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getObject(Column, Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getObject(ResultSet, int, Map) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
getObject(Object, int, Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id.
getObject(Column, Object, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column.
getObject(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getObject(int, Map) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getObject(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getObject(String, Map) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getObject(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getObject(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getObject(int, Map) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getObject(String, Map) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getObjectCount() - Method in interface org.apache.openjpa.enhance.DynamicStorage
Return the number of object fields
getObjectExtension(String) - Method in class org.apache.openjpa.meta.Extensions
Get the value of an extension.
getObjectExtension(String, String) - Method in class org.apache.openjpa.meta.Extensions
Get the value of an extension.
getObjectId(Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
getObjectId(JDBCStore, Result, ForeignKey, boolean, Joins) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Return the oid value stored in the result.
getObjectId(ClassMetaData) - Method in class org.apache.openjpa.kernel.AbstractPCResultObjectProvider
Implement this method to extract the object id value from the current record of the input.
getObjectId(Object) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getObjectId(Object) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getObjectId() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
getObjectId() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
getObjectId(Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return the object id of the given value.
getObjectId(Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
getObjectId() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
getObjectId() - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return the instance's object id.
getObjectId() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
getObjectId(Object) - Method in interface org.apache.openjpa.kernel.StoreContext
Return the oid of the given instance.
getObjectId(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getObjectId(Object) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return the oid of the given instance.
getObjectIdBytecode() - Method in class org.apache.openjpa.enhance.PCEnhancer
Return the bytecode representations of any oid classes that must be manipulated.
getObjectIdClass(Class) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getObjectIdClass(Class) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return the application identity class the given persistent class uses for object ids, or null if not a type that uses application identity.
getObjectIdFieldType() - Method in class org.apache.openjpa.meta.FieldMetaData
For a primary key field, return the type of the corresponding object id class field.
getObjectIdFieldTypeCode() - Method in class org.apache.openjpa.meta.FieldMetaData
For a primary key field, return the type of the corresponding object id class field.
getObjectIdType(Class) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getObjectIdType(Class) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getObjectIdType(Class) - Method in interface org.apache.openjpa.kernel.StoreContext
Return the application or datastore identity class the given persistent class uses for object ids.
getObjectIdType() - Method in class org.apache.openjpa.meta.ClassMetaData
The metadata-specified class to use for the object ID.
getObjectInternal(Object, int, Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
Return the value stored in the given id or column.
getObjectInternal(Object, int, Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getObjects() - Method in class org.apache.openjpa.jdbc.schema.XMLSchemaSerializer
 
getObjects() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
Return the current set of objects for serialization.
getObjects() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
 
getOpenBrace(int) - Method in class org.apache.openjpa.lib.util.CodeFormat
Open brace string.
getOpenJPATables() - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Whether to generate info on special tables used by OpenJPA components for bookkeeping.
getOpenJPATables() - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Whether to act on special tables used by OpenJPA components for bookkeeping.
getOpenParen(boolean) - Method in class org.apache.openjpa.lib.util.CodeFormat
Open parentheses string.
getOperation(StoreQuery) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery.AbstractExecutor
 
getOperation() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getOperation() - Method in interface org.apache.openjpa.kernel.QueryContext
Returns the operation that this query will be expected to perform.
getOperation() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getOperation(StoreQuery) - Method in interface org.apache.openjpa.kernel.StoreQuery.Executor
Returns the operation this executor is meant to execute.
getOperation() - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Query operation type.
getOperation() - Method in class org.apache.openjpa.persistence.QueryImpl
 
getOptimistic() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Whether to use optimistic transactions by default.
getOptimistic() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getOptimistic() - Method in interface org.apache.openjpa.kernel.Broker
Whether to use optimistic transactional semantics.
getOptimistic() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getOptimistic() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getOptimistic() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getOptimistic() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether to use optimistic transactional semantics.
getOrderColumn() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Field order column, if any.
getOrderColumn() - Method in class org.apache.openjpa.jdbc.meta.FieldMappingInfo
Raw synthetic ordering column.
getOrderColumn(FieldMapping, Table, boolean) - Method in class org.apache.openjpa.jdbc.meta.FieldMappingInfo
Return the ordering column for this field, or null if none.
getOrderColumnIO() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
I/O information for order column.
getOrderColumnName() - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default base name for order columns, or null to the mapping's built-in name.
getOrderDeclaration() - Method in class org.apache.openjpa.meta.FieldMetaData
String declaring the orderings for this field to be applied on load, or null.
getOrderDirtyObjects() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getOrderDirtyObjects() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getOrderDirtyObjects() - Method in interface org.apache.openjpa.kernel.StoreContext
Whether to maintain the order in which objects are dirtied for StoreContext.getDirtyObjects().
getOrderDirtyObjects() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getOrderDirtyObjects() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether dirty objects will be returned in the order they were dirtied.
getOrdered() - Method in class org.apache.openjpa.jdbc.sql.RowManagerImpl
Return the ordered primary rows.
getOrdering() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
getOrdering() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getOrdering() - Method in interface org.apache.openjpa.jdbc.sql.Select
Return the ordering SQL for this select.
getOrdering() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getOrdering() - Method in interface org.apache.openjpa.jdbc.sql.Union
Get the union-level ordering, if any.
getOrderingValue(Result, int) - Method in interface org.apache.openjpa.jdbc.sql.MergedResult.ResultComparator
Return the ordering value of the current row of the given result.
getOrderingValue(StoreQuery, Object[], Object, int) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery.AbstractExecutor
 
getOrderingValue(Object, int, ResultObjectProvider) - Method in class org.apache.openjpa.kernel.OrderingMergedResultObjectProvider
 
getOrderingValue(StoreQuery, Object[], Object, int) - Method in interface org.apache.openjpa.kernel.StoreQuery.Executor
Extract the value of the orderIndexth ordering expression in Query#getOrderingClauses from the given result object.
getOrderingValue(Object, int, ResultObjectProvider) - Method in class org.apache.openjpa.lib.rop.MergedResultObjectProvider
Return the value to use for ordering on the given result value.
getOrderLists() - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Whether to order lists and arrays using a dedicated ordering column by default.
getOrders() - Method in class org.apache.openjpa.meta.FieldMetaData
The orderings for this field to be applied on load, or empty array.
getOrphanedKeyAction() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The action to take when an orphaned key is detected.
getOrphanedKeyAction() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getOrphanedKeyActionInstance() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The action to take when an orphaned key is detected.
getOrphanedKeyActionInstance() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getOutputStream(String, ClassLoader) - Static method in class org.apache.openjpa.lib.util.Files
Return an output stream to the stream(stdout or stderr) or file named by the given string.
getOwner() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
getOwner() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
getOwner() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
getOwner() - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return the owning state if this is an embedded instance.
getOwner() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
getOwner() - Method in class org.apache.openjpa.lib.util.concurrent.ReentrantLock
null if not owned.
getOwner() - Method in class org.apache.openjpa.lib.util.concurrent.WaitQueue.WaitNode
 
getOwner() - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
getOwner() - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
getOwner() - Method in interface org.apache.openjpa.util.Proxy
Return the owning object.
getOwner() - Method in class org.apache.openjpa.util.ProxyArrayList
 
getOwner() - Method in class org.apache.openjpa.util.ProxyGregorianCalendar
 
getOwner() - Method in class org.apache.openjpa.util.ProxyHashMap
 
getOwner() - Method in class org.apache.openjpa.util.ProxyHashSet
 
getOwner() - Method in class org.apache.openjpa.util.ProxyHashtable
 
getOwner() - Method in class org.apache.openjpa.util.ProxyLinkedList
 
getOwner() - Method in class org.apache.openjpa.util.ProxyProperties
 
getOwner() - Method in class org.apache.openjpa.util.ProxySQLDate
 
getOwner() - Method in class org.apache.openjpa.util.ProxyTime
 
getOwner() - Method in class org.apache.openjpa.util.ProxyTimestamp
 
getOwner() - Method in class org.apache.openjpa.util.ProxyTreeMap
 
getOwner() - Method in class org.apache.openjpa.util.ProxyTreeSet
 
getOwner() - Method in class org.apache.openjpa.util.ProxyUtilDate
 
getOwner() - Method in class org.apache.openjpa.util.ProxyVector
 
getOwnerField() - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
getOwnerField() - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
getOwnerField() - Method in interface org.apache.openjpa.util.Proxy
Return the owning field index.
getOwnerField() - Method in class org.apache.openjpa.util.ProxyArrayList
 
getOwnerField() - Method in class org.apache.openjpa.util.ProxyGregorianCalendar
 
getOwnerField() - Method in class org.apache.openjpa.util.ProxyHashMap
 
getOwnerField() - Method in class org.apache.openjpa.util.ProxyHashSet
 
getOwnerField() - Method in class org.apache.openjpa.util.ProxyHashtable
 
getOwnerField() - Method in class org.apache.openjpa.util.ProxyLinkedList
 
getOwnerField() - Method in class org.apache.openjpa.util.ProxyProperties
 
getOwnerField() - Method in class org.apache.openjpa.util.ProxySQLDate
 
getOwnerField() - Method in class org.apache.openjpa.util.ProxyTime
 
getOwnerField() - Method in class org.apache.openjpa.util.ProxyTimestamp
 
getOwnerField() - Method in class org.apache.openjpa.util.ProxyTreeMap
 
getOwnerField() - Method in class org.apache.openjpa.util.ProxyTreeSet
 
getOwnerField() - Method in class org.apache.openjpa.util.ProxyUtilDate
 
getOwnerField() - Method in class org.apache.openjpa.util.ProxyVector
 
getOwnerMetaData() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
getOwnerMetaData() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
getOwnerMetaData() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
getOwnerMetaData() - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return the owning value.
getOwnerMetaData() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
getPackage() - Method in class org.apache.openjpa.lib.meta.CFMetaDataSerializer
The default package for objects being serialized.
getPackage(Object) - Method in class org.apache.openjpa.lib.meta.CFMetaDataSerializer
Return the package name of the given object, or null if not in a package.
getPackage(Object) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
 
getPackageAttributeName() - Method in class org.apache.openjpa.lib.meta.CFMetaDataParser
The attribute of the package element that holds the name, or null to use the element text.
getPackageAttributeName() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
getPackageElementDepth() - Method in class org.apache.openjpa.lib.meta.CFMetaDataParser
The depth of the package element.
getPackageFile(File, String, boolean) - Static method in class org.apache.openjpa.lib.util.Files
Return the file for the given package.
getPackageName() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Return the default package for the generated classes, or null if unset.
getPackageName() - Method in class org.apache.openjpa.lib.util.Localizer.Message
 
getPagedFields(Select, ClassMapping, JDBCStore, JDBCFetchConfiguration, int, long) - Static method in class org.apache.openjpa.jdbc.kernel.PagingResultObjectProvider
Return a bit set representing batch select fields that will be paged, or null if no fields need paging, which indicates that this provider should not be used.
getPageSize() - Method in class org.apache.openjpa.jdbc.kernel.PagingResultObjectProvider
Return the page size in use.
getParameter(String) - Method in class org.apache.openjpa.lib.util.ParameterTemplate
Return the value set for the given parameter.
getParameterCount() - Method in class org.apache.openjpa.jdbc.sql.RowImpl
The number of parameters that will be set for this row.
getParameterDeclaration() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getParameterDeclaration() - Method in interface org.apache.openjpa.kernel.QueryContext
The parameter declaration.
getParameterDeclaration() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getParameterizedTypes(Field) - Static method in class org.apache.openjpa.lib.util.JavaVersions
Collects the parameterized type declarations for a given field.
getParameterizedTypes(Method) - Static method in class org.apache.openjpa.lib.util.JavaVersions
Collects the parameterized return type declarations for a given method.
getParameterMetaData() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getParameterMetaData() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
getParameterName() - Method in interface org.apache.openjpa.kernel.exps.Parameter
Returns the name of the parameter.
getParameters() - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Return the list of parameter values.
getParameterTypes(StoreQuery) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery.AbstractExecutor
 
getParameterTypes() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getParameterTypes() - Method in interface org.apache.openjpa.kernel.QueryContext
Return a map of parameter name to type for this query.
getParameterTypes() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getParameterTypes(StoreQuery) - Method in interface org.apache.openjpa.kernel.StoreQuery.Executor
Return a map of parameter names to types.
getParens() - Method in class org.apache.openjpa.lib.util.CodeFormat
Paired parentheses for empty method parameters.
getParent() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getParent() - Method in interface org.apache.openjpa.jdbc.sql.Select
Return the parent of this select, if it is a subselect.
getParent() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getParseComments() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Whether to parse element comments.
getParseText() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Whether to parse element text.
getParseType() - Method in interface org.apache.openjpa.kernel.exps.Literal
The type the literal was parsed as.
getPayloadType() - Method in class org.apache.openjpa.event.RemoteCommitEvent
The event PAYLOAD constant.
getPCDataGenerator() - Method in interface org.apache.openjpa.datacache.DataCacheManager
Return the PCData generator if configured.
getPCDataGenerator() - Method in class org.apache.openjpa.datacache.DataCacheManagerImpl
 
getPCPrimaryKey(Object, int) - Method in interface org.apache.openjpa.enhance.StateManager
Return the persistence-capable primary key object by extracting the identity value of the related instance stored in the given field from the given object id.
getPCPrimaryKey(Object, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
getPCPrimaryKey(Object, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
getPCPrimaryKey(Object, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
getPCPrimaryKey(Object, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
getPCResults() - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping
Return the mapped persistence-capable types in the query result.
getPCState() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
getPCState() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
getPCState() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
getPCState() - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return the state that this object is in.
getPCState() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
getPCSubclasses() - Method in class org.apache.openjpa.meta.ClassMetaData
Return the known persistence capable subclasses of the described type, or empty array if none or if this is embedded metadata.
getPCSubclassMappings() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Convenience method to perform cast from ClassMetaData.getPCSubclassMetaDatas().
getPCSubclassMetaDatas() - Method in class org.apache.openjpa.meta.ClassMetaData
Return the metadata for the known persistence capable subclasses of the described type, or empty array if none or if this is embedded metadata.
getPCSuperclass() - Method in class org.apache.openjpa.meta.ClassMetaData
The persistence capable superclass of the described type.
getPCSuperclassMapping() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Convenience method to perform cast from ClassMetaData.getPCSuperclassMetaData().
getPCSuperclassMetaData() - Method in class org.apache.openjpa.meta.ClassMetaData
The metadata for this class' superclass.
getPCType() - Method in class org.apache.openjpa.kernel.AbstractPCResultObjectProvider
Implement this method to extract the type of the pc stored in the current record of the input.
getPendingTransactionalObjects() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getPendingTransactionalObjects() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getPendingTransactionalObjects() - Method in interface org.apache.openjpa.kernel.StoreContext
Return a list of instances which will become transactional upon the next transaction.
getPendingTransactionalObjects() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getPendingTransactionalObjects() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return a set of instances which will become transactional upon the next transaction.
getPendingTransactionalStates() - Method in class org.apache.openjpa.kernel.BrokerImpl
Return a copy of all state managers which will become transactional upon the next transaction.
getPersistedClasses() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getPersistedClasses() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return the set of classes that have been made persistent in the current transaction.
getPersistedObjectIds() - Method in class org.apache.openjpa.event.RemoteCommitEvent
When the event type is PAYLOAD_OIDS_WITH_ADDS, return the set of object IDs for added objects.
getPersistedTypeNames() - Method in class org.apache.openjpa.event.RemoteCommitEvent
For all event types, return the set of class names for the classes of inserted objects.
getPersistedTypes() - Method in class org.apache.openjpa.event.TransactionEvent
Return the unmodifiable the set of classes of persistence capable objects that were created in the transaction.
getPersistedTypes() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getPersistedTypes() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getPersistedTypes() - Method in interface org.apache.openjpa.kernel.StoreContext
Return the set of classes that have been made persistent in the current transaction.
getPersistenceAware(Class) - Method in class org.apache.openjpa.meta.MetaDataRepository
Gets the metadata corresponding to the given persistence-aware class.
getPersistenceAwares() - Method in class org.apache.openjpa.meta.MetaDataRepository
Gets all the metadatas for persistence-aware classes
getPersistenceCapable() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
getPersistenceCapable() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
getPersistenceCapable() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
getPersistenceCapable() - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return the PersistenceCapable instance that provides access to the instance managed by this state manager.
getPersistenceCapable() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
getPersistenceProviderClassName() - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
getPersistenceStrategy(FieldMetaData, Member) - Static method in class org.apache.openjpa.persistence.PersistenceMetaDataDefaults
Return the code for the strategy of the given member.
getPersistenceUnitName() - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
getPersistenceUnitRootUrl() - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
getPersistenceXmlFileUrl() - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
The location of the persistence.xml resource.
getPersistentSuperclass(Class) - Static method in class org.apache.openjpa.enhance.PCRegistry
Return the persistent superclass for a PersistenceCapable class, or null if none.
getPersistentTypeNames(boolean, ClassLoader) - Method in class org.apache.openjpa.jdbc.meta.MetaDataPlusMappingFactory
 
getPersistentTypeNames(boolean, ClassLoader) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
 
getPersistentTypeNames(boolean, ClassLoader) - Method in class org.apache.openjpa.meta.AbstractMetaDataFactory
 
getPersistentTypeNames(boolean, ClassLoader) - Method in class org.apache.openjpa.meta.DelegatingMetaDataFactory
 
getPersistentTypeNames(boolean, ClassLoader) - Method in interface org.apache.openjpa.meta.MetaDataFactory
Return all persistent class names, using the metadata locations supplied in configuration, optionally scanning the classpath.
getPersistentTypeNames(boolean, ClassLoader) - Method in class org.apache.openjpa.meta.MetaDataRepository
Return the set of configured persistent classes, or null if the user did not configure any.
getPersistentTypeNames(boolean, ClassLoader) - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
getPinnedKeys() - Method in class org.apache.openjpa.util.CacheMap
The keys pinned into the map.
getPlaceholderValueString(Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return a SQL string to act as a placeholder for the given column.
getPlaceholderValueString(Column) - Method in class org.apache.openjpa.jdbc.sql.FirebirdDictionary
 
getPlaceholderValueString(Column) - Method in class org.apache.openjpa.jdbc.sql.HSQLDictionary
 
getPlatform() - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
Returns a string name to identify the platform of this store manager.
getPlugin(String, String) - Static method in class org.apache.openjpa.lib.conf.Configurations
Combine the given class name and properties into a plugin string.
getPolymorphic() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
getPolymorphic() - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
The degree to which this relation is polymorphic.
getPolymorphic() - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
getPooledFactory(OpenJPAConfiguration) - Static method in class org.apache.openjpa.kernel.AbstractBrokerFactory
Return the pooled factory matching the given configuration, or null if none.
getPooledFactory(Map) - Static method in class org.apache.openjpa.kernel.AbstractBrokerFactory
Return the pooled factory matching the given configuration data, or null if none.
getPopulateDataCache() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getPopulateDataCache() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getPopulateDataCache() - Method in interface org.apache.openjpa.kernel.StoreContext
Whether objects accessed during this transaction will be added to the store cache.
getPopulateStoreCache() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getPopulateStoreCache() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether objects accessed during this transaction will be added to the store cache.
getPort() - Method in class org.apache.openjpa.event.TCPRemoteCommitProvider
The port that this provider should listen on.
getPositionalParameters() - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
The positional parameters for the query; empty array if none or if query uses named parameters.
getPositionalParameters() - Method in class org.apache.openjpa.persistence.QueryImpl
 
getPreferredType(int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return the preferred Types type for the given one.
getPreferredType(int) - Method in class org.apache.openjpa.jdbc.sql.HSQLDictionary
 
getPreferredType(int) - Method in class org.apache.openjpa.jdbc.sql.MySQLDictionary
 
getPreferredType(int) - Method in class org.apache.openjpa.jdbc.sql.PointbaseDictionary
 
getPreFlush() - Method in class org.apache.openjpa.kernel.InMemorySavepointManager
Return whether to call Broker.preFlush() when a savepoint is set.
getPrettyPrint() - Method in class org.apache.openjpa.lib.jdbc.LoggingConnectionDecorator
 
getPrettyPrintLineLength() - Method in class org.apache.openjpa.lib.jdbc.LoggingConnectionDecorator
 
getPrimaryKey(ClassMapping) - Method in class org.apache.openjpa.jdbc.kernel.ClassTableJDBCSeq
 
getPrimaryKey(ClassMapping) - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
Return the primary key value for the given class.
getPrimaryKey(ClassMapping) - Method in class org.apache.openjpa.jdbc.kernel.ValueTableJDBCSeq
 
getPrimaryKey() - Method in class org.apache.openjpa.jdbc.schema.Table
Return the primary key for the table, if any.
getPrimaryKey() - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
 
getPrimaryKey() - Method in interface org.apache.openjpa.jdbc.sql.Row
Return the instance that controls this row.
getPrimaryKey() - Method in class org.apache.openjpa.jdbc.sql.RowImpl
This implementation does not track primary keys.
getPrimaryKeyColumn() - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
The name of the table's primary key column.
getPrimaryKeyColumn() - Method in class org.apache.openjpa.jdbc.meta.SequenceMapping
Name of primary key column, if any.
getPrimaryKeyColumn(Column) - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Return the primary key column joined to the given local column.
getPrimaryKeyColumn() - Method in class org.apache.openjpa.jdbc.schema.TableSchemaFactory
The name of the primary key column on the schema definition table.
getPrimaryKeyColumnName() - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
The name of the primary key column.
getPrimaryKeyColumns() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
The columns this mapping uses to uniquely identify an object.
getPrimaryKeyColumns() - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Return the foreign columns in the foreign key, in join-order with the result of ForeignKey.getColumns().
getPrimaryKeyConstant(Column) - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Return the constant value assigned to the given primary key column.
getPrimaryKeyConstants() - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Return the constant values assigned to the primary key columns returned by ForeignKey.getConstantPrimaryKeyColumns().
getPrimaryKeyConstraintSQL(PrimaryKey) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return the declaration SQL for the given primary key.
getPrimaryKeyConstraintSQL(PrimaryKey) - Method in class org.apache.openjpa.jdbc.sql.FoxProDictionary
 
getPrimaryKeyConstraintSQL(PrimaryKey) - Method in class org.apache.openjpa.jdbc.sql.HSQLDictionary
 
getPrimaryKeyFieldMappings() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Convenience method to perform cast from ClassMetaData.getPrimaryKeyFields().
getPrimaryKeyFields() - Method in class org.apache.openjpa.meta.ClassMetaData
Return primary key fields, or empty array if none.
getPrimaryKeyIndex() - Method in class org.apache.openjpa.meta.FieldMetaData
The absolute primary key index for this field, or -1 if not a primary key.
getPrimaryKeyName(ClassMapping, Table) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Return the name of the primary key for the table of the given class, or null for database default.
getPrimaryKeyName(ClassMapping, Table) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
getPrimaryKeyName(ClassMapping, Table) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
getPrimaryKeyOnJoin() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Return true if join tables are allowed to have primary keys, false if all primary key tables will be mapped as persistent classes.
getPrimaryKeys() - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Whether primary keys on existing tables should be manipulated.
getPrimaryKeys() - Method in class org.apache.openjpa.jdbc.schema.LazySchemaFactory
 
getPrimaryKeys() - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Return whether primary keys should be generated.
getPrimaryKeys() - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Whether primary keys on existing tables should be manipulated.
getPrimaryKeys(DatabaseMetaData, String, String, String, Connection) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Reflect on the schema to find primary keys for the given table pattern.
getPrimaryKeys(DatabaseMetaData, String, String, String, Connection) - Method in class org.apache.openjpa.jdbc.sql.FoxProDictionary
 
getPrimaryKeys(DatabaseMetaData, String, String, String, Connection) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
getPrimaryKeys(String, String, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getPrimaryKeySchemaName() - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
The name of the primary key table's schema.
getPrimaryKeysFromBestRowIdentifier(DatabaseMetaData, String, String, String, Connection) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Reflect on the schema to find primary keys for the given table pattern.
getPrimaryKeysFromGetPrimaryKeys(DatabaseMetaData, String, String, String, Connection) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Reflect on the schema to find primary keys for the given table pattern.
getPrimaryKeyTable() - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Returns the table this foreign key is linking to, if it is known yet.
getPrimaryKeyTableName() - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
The name of the primary key table.
getPrimaryKeyValue() - Method in class org.apache.openjpa.jdbc.kernel.ValueTableJDBCSeq
The primary key value for this row.
getPrimaryKeyValue(Result, Column[], ForeignKey, JDBCStore, Joins) - Method in class org.apache.openjpa.jdbc.meta.DelegatingJoinable
 
getPrimaryKeyValue(Result, Column[], ForeignKey, JDBCStore, Joins) - Method in interface org.apache.openjpa.jdbc.meta.Joinable
Return the value for this joinable from the given result, using the given columns.
getPrimaryKeyValue() - Method in class org.apache.openjpa.jdbc.meta.SequenceMapping
Primary key value, if not auto-determined.
getPrimaryKeyValue(Result, Column[], ForeignKey, JDBCStore, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
getPrimaryKeyValue(Result, Column[], ForeignKey, JDBCStore, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
getPrimaryKeyValue(Result, Column[], ForeignKey, JDBCStore, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
getPrimaryKeyValue(Result, Column[], ForeignKey, JDBCStore, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
getProcedureColumns(String, String, String, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getProcedures(String, String, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getProcedureTerm() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getProductDerivations() - Static method in class org.apache.openjpa.lib.conf.ProductDerivations
Return all the product derivations registered in the current classloader
getProductName() - Method in interface org.apache.openjpa.lib.conf.Configuration
Return the product name.
getProductName() - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
getProjectionAliases(StoreQuery) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery.AbstractExecutor
 
getProjectionAliases() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getProjectionAliases() - Method in interface org.apache.openjpa.kernel.QueryContext
If this query is a projection, return the projection aliases.
getProjectionAliases() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getProjectionAliases(StoreQuery) - Method in interface org.apache.openjpa.kernel.StoreQuery.Executor
Return the alias for each projection element, or empty array if not a projection.
getProjectionTypes(StoreQuery) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery.AbstractExecutor
 
getProjectionTypes() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getProjectionTypes() - Method in interface org.apache.openjpa.kernel.QueryContext
If this query is a projection, return the projection types.
getProjectionTypes() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getProjectionTypes(StoreQuery) - Method in interface org.apache.openjpa.kernel.StoreQuery.Executor
Return the expected types of the projections used by this query, or an empty array if not a projection.
getProperties() - Method in class org.apache.openjpa.abstractstore.AbstractStoreBrokerFactory
 
getProperties() - Method in class org.apache.openjpa.jdbc.kernel.JDBCBrokerFactory
 
getProperties() - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
Subclasses should override this method to add a Platform property listing the runtime platform, such as: OpenJPA JDBC Edition: Oracle Database
getProperties() - Method in interface org.apache.openjpa.kernel.BrokerFactory
Return properties describing this runtime.
getProperties() - Method in class org.apache.openjpa.kernel.DelegatingBrokerFactory
 
getProperties() - Method in interface org.apache.openjpa.lib.conf.ConfigurationProvider
Return properties loaded thus far, or empty map if none.
getProperties(String) - Static method in class org.apache.openjpa.lib.conf.Configurations
Return the properties part of the given plugin string, or null if none.
getProperties() - Method in class org.apache.openjpa.lib.conf.MapConfigurationProvider
 
getProperties() - Method in class org.apache.openjpa.lib.conf.PluginListValue
The plugin properties.
getProperties() - Method in class org.apache.openjpa.lib.conf.PluginValue
The plugin properties.
getProperties() - Method in class org.apache.openjpa.persistence.EntityManagerFactoryImpl
 
getProperties() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManagerFactory
Return properties describing this runtime.
getProperties() - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
getPropertiesResource() - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
Return the resource that was set via auto-configuration methods ConfigurationImpl.setProperties(java.lang.String) or ConfigurationImpl.setPropertiesFile(java.io.File), or null if none.
getProperty(String) - Method in class org.apache.openjpa.jdbc.meta.PropertiesReverseCustomizer
Return the property value for the given key, or null if none.
getProperty(String, Map) - Static method in class org.apache.openjpa.lib.conf.Configurations
Get the property under the given key, prefixed with any possible configuration prefix.
getProperty() - Method in class org.apache.openjpa.lib.conf.Value
The property name that will be used when setting or getting this value in a Map.
getProperty(String) - Method in class org.apache.openjpa.lib.util.FormatPreservingProperties
 
getProperty(String, String) - Method in class org.apache.openjpa.lib.util.FormatPreservingProperties
 
getProperty(String, String, String) - Method in class org.apache.openjpa.lib.util.Options
Specialization of Properties.getProperty(java.lang.String) to allow a value to appear under either of two keys; useful for short and long versions of command-line flags.
getPropertyDescriptors() - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
getProvider() - Method in class org.apache.openjpa.conf.RemoteCommitProviderValue
The cached provider.
getProxyManager() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The plugin string for the ProxyManager to use for second class object proxies.
getProxyManager() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getProxyManagerInstance() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The ProxyManager to use.
getProxyManagerInstance() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getProxyType() - Method in class org.apache.openjpa.meta.FieldMetaData
The type this field was initialized with, and therefore the type to use for proxies when loading data into this field.
getQuery() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getQuery() - Method in interface org.apache.openjpa.kernel.QueryContext
Return the query for this context.
getQuery() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getQueryCache() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The plugin to use for level-2 data store query caching.
getQueryCache() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getQueryCache() - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
getQueryCache() - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Return whether or not query caching is enabled.
getQueryCache() - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
getQueryCompilationCache() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Configuration settings for the query compilation cache to use.
getQueryCompilationCache() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getQueryCompilationCacheInstance() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Configuration settings for the query compilation cache to use.
getQueryCompilationCacheInstance() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getQueryKey(Class, String) - Static method in class org.apache.openjpa.meta.MetaDataRepository
Return a unique key for a given class / name.
getQueryMetaData(Class, String, ClassLoader, boolean) - Method in class org.apache.openjpa.meta.MetaDataRepository
Return query metadata for the given class, name, and classloader.
getQueryMetaDatas() - Method in class org.apache.openjpa.meta.MetaDataRepository
Return the cached query metadata.
getQueryResultCache() - Method in class org.apache.openjpa.persistence.EntityManagerFactoryImpl
 
getQueryResultCache() - Method in interface org.apache.openjpa.persistence.FetchPlan
Return whether or not query caching is enabled.
getQueryResultCache() - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
getQueryResultCache() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManagerFactory
Access query result cache.
getQueryResultMapping(Class, String, ClassLoader, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Return the query result mapping for the given name.
getQueryResultMappings() - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Return all cached query result mappings.
getQueryScope(String, ClassLoader) - Method in class org.apache.openjpa.meta.AbstractMetaDataFactory
 
getQueryScope(String, ClassLoader) - Method in class org.apache.openjpa.meta.DelegatingMetaDataFactory
 
getQueryScope(String, ClassLoader) - Method in interface org.apache.openjpa.meta.MetaDataFactory
Return the type defining the given query name, if any.
getQueryScope(String, ClassLoader) - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
getQueryScope(String, ClassLoader) - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
 
getQueryString() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getQueryString() - Method in interface org.apache.openjpa.kernel.QueryContext
The query string.
getQueryString() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getQueryString() - Method in class org.apache.openjpa.meta.QueryMetaData
The full query string, or null if none.
getQueryString() - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Query string.
getQueryString() - Method in class org.apache.openjpa.persistence.QueryImpl
 
getQueryTimeout() - Method in class org.apache.openjpa.lib.jdbc.ConfiguringConnectionDecorator
The number of seconds to wait for a query to execute before terminating it.
getQueryTimeout() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getQueryTimeout() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
getQueryTimeout() - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
getQueuedThreads() - Method in class org.apache.openjpa.lib.util.concurrent.ReentrantLock
Returns a collection containing threads that may be waiting to acquire this lock.
getQueueLength() - Method in class org.apache.openjpa.lib.util.concurrent.ReentrantLock
Returns an estimate of the number of threads waiting to acquire this lock.
getQuotedNumbersInQueries() - Method in class org.apache.openjpa.conf.Compatibility
Whether to interpret quoted numbers in query strings as numbers.
getRange(StoreQuery, Object[], StoreQuery.Range) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery.AbstractExecutor
 
getRange(StoreQuery, Object[], StoreQuery.Range) - Method in interface org.apache.openjpa.kernel.StoreQuery.Executor
Mutate the given range to set any range information stored in the query string and/or parameters.
getReadLockLevel() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The default read lock level to use during non-optimistic transactions.
getReadLockLevel() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getReadLockLevel() - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
getReadLockLevel() - Method in interface org.apache.openjpa.kernel.FetchConfiguration
The lock level to use for locking loaded objects.
getReadLockLevel() - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
getReadLockLevelConstant() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The numeric read lock level.
getReadLockLevelConstant() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getReadLockMode() - Method in interface org.apache.openjpa.persistence.FetchPlan
The lock level to use for locking loaded objects.
getReadLockMode() - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
getReadSchema() - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Set to true to read the entire schema before mapping.
getRecoveryTimeMillis() - Method in class org.apache.openjpa.event.TCPRemoteCommitProvider
The number of milliseconds to wait before retrying to reconnect to a peer after it becomes unreachable.
getRecursionDepth(FieldMetaData) - Method in class org.apache.openjpa.meta.FetchGroup
Recursion depth for the given field.
getRef(Object, Map) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getRef(Column, Map, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getRef(ResultSet, int, Map) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getRef(Object, Map) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getRef(Column, Map, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getRef(Object, Map) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id; may not be supported by results that are not backed by a SQL result set.
getRef(Column, Map, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column; may not be supported by results that are not backed by a SQL result set.
getRef(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getRef(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getRef(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getRef(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getReference(Class<T>, Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getRefInternal(Object, Map, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getRefInternal(Object, Map, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getRegisteredTypes() - Static method in class org.apache.openjpa.enhance.PCRegistry
Returns a collection of class objects of the registered persistence-capable classes.
getRelated() - Method in class org.apache.openjpa.event.LifecycleEvent
Return the related object.
getRelationIdCallback(Column) - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
Return the recorded callbacks for the given relation id column.
getRelationIdColumns() - Method in class org.apache.openjpa.jdbc.schema.Table
Return this table's relation id columns.
getRelationIdSet(Column) - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
Return the recorded value for the given relation id column.
getRelationJoins() - Method in class org.apache.openjpa.jdbc.sql.Join
If joining a relation, the joins leading to the relation.
getRelationTarget() - Method in class org.apache.openjpa.jdbc.sql.Join
If joining a relation, the target type.
getRemoteCommitEventManager() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The remote event manager that manages this configuration's remote event listeners.
getRemoteCommitEventManager() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getRemoteCommitProvider() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The plugin to use for remote commit notification.
getRemoteCommitProvider() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getRemoteCommitProvider() - Method in class org.apache.openjpa.event.RemoteCommitEventManager
Return the RemoteCommitProvider that this manager uses.
getRemoved() - Method in class org.apache.openjpa.util.AbstractChangeTracker
 
getRemoved() - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
getRemoved() - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
getRemoved() - Method in interface org.apache.openjpa.util.ChangeTracker
Return the set of values that need to be removed from the managed container.
getRemovedClasses() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getRemovedClasses() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return the set of classes that have been deleted in the current transaction.
getRepository() - Method in class org.apache.openjpa.jdbc.meta.Discriminator
 
getRepository() - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Return the repository to use to access mapping information.
getRepository() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Return the mapping repository used to hold generated mappings.
getRepository() - Method in class org.apache.openjpa.jdbc.meta.Version
 
getRepository() - Method in interface org.apache.openjpa.meta.AbstractCFMetaDataFactory.Parser
Returns the repository for this parser.
getRepository() - Method in class org.apache.openjpa.meta.ClassMetaData
Return the owning repository.
getRepository() - Method in class org.apache.openjpa.meta.Extensions
Return the metadata repository.
getRepository() - Method in class org.apache.openjpa.meta.FieldMetaData
The metadata repository.
getRepository() - Method in interface org.apache.openjpa.meta.MetaDataContext
Access metadata repository.
getRepository() - Method in class org.apache.openjpa.meta.MetaDataTool
The repository to use to hold metadata.
getRepository() - Method in class org.apache.openjpa.meta.NonPersistentMetaData
Owning repository.
getRepository() - Method in class org.apache.openjpa.meta.SequenceMetaData
The owning repository.
getRepository() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
getRepository() - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Returns the repository for this parser.
getRepository() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Returns the repository for this parser.
getRequiresExtent() - Method in class org.apache.openjpa.meta.ClassMetaData
Whether the type requires extent management.
getResolve() - Method in class org.apache.openjpa.jdbc.meta.Discriminator
Resolve mode.
getResolve() - Method in class org.apache.openjpa.jdbc.meta.Version
Resolve mode.
getResolve() - Method in class org.apache.openjpa.meta.ClassMetaData
The resolve mode for this metadata.
getResolve() - Method in class org.apache.openjpa.meta.FieldMetaData
Resolve mode for this field.
getResolve() - Method in class org.apache.openjpa.meta.MetaDataRepository
The metadata resolution mode.
getResolve() - Method in interface org.apache.openjpa.meta.ValueMetaData
Resolve mode for metadata.
getResolve() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
getResolver() - Method in class org.apache.openjpa.kernel.ExpressionStoreQuery
Resolver used in parsing.
getResourceName() - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
 
getResourceName() - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping
 
getResourceName() - Method in class org.apache.openjpa.jdbc.schema.Sequence
 
getResourceName() - Method in class org.apache.openjpa.jdbc.schema.Table
 
getResourceName() - Method in interface org.apache.openjpa.lib.meta.SourceTracker
Return the domain-meaningful name of the resource that was loaded from this source.
getResourceName() - Method in class org.apache.openjpa.meta.ClassMetaData
 
getResourceName() - Method in class org.apache.openjpa.meta.NonPersistentMetaData
 
getResourceName() - Method in class org.apache.openjpa.meta.QueryMetaData
 
getResourceName() - Method in class org.apache.openjpa.meta.SequenceMetaData
 
getResourceName() - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
getRestoreFieldState() - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSavepointManager
Return whether to retain in-memory copies of field values for restore on rollback.
getRestoreState() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Whether to restore initial state on rollback by default.
getRestoreState() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getRestoreState() - Method in interface org.apache.openjpa.kernel.Broker
Whether to restore an object's original state on rollback.
getRestoreState() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getRestoreState() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getRestoreState() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getRestoreState() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether to restore an object's original state on rollback.
getRestoreStateConstant() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Return the RestoreState constant.
getRestoreStateConstant() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getResult() - Method in class org.apache.openjpa.jdbc.kernel.SelectResultObjectProvider
 
getResultArgument(ValueMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractValueHandler
 
getResultArgument(ValueMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.ObjectIdValueHandler
 
getResultArgument(ValueMapping) - Method in interface org.apache.openjpa.jdbc.meta.ValueHandler
Return the argument to pass to the result set when loading data via Result.getObject(java.lang.Object, int, java.lang.Object), or null if none.
getResultArguments() - Method in interface org.apache.openjpa.jdbc.meta.Embeddable
Return the arguments needed to extract datastore values via Result.getObject(java.lang.Object, int, java.lang.Object) for each column.
getResultArguments() - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
getResultArguments() - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
getResultArguments() - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
getResultArguments() - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
getResultClass(StoreQuery) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery.AbstractExecutor
 
getResultClass(StoreQuery) - Method in interface org.apache.openjpa.kernel.StoreQuery.Executor
Returns the result class, if any.
getResultClass() - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Query result element type.
getResultClass() - Method in class org.apache.openjpa.persistence.QueryImpl
 
getResultList() - Method in class org.apache.openjpa.lib.rop.ResultListIterator
 
getResultList() - Method in class org.apache.openjpa.persistence.QueryImpl
 
getResultMappingName() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getResultMappingName() - Method in interface org.apache.openjpa.kernel.QueryContext
Name of a mapping from the result data to its object representation.
getResultMappingName() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getResultMappingScope() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getResultMappingScope() - Method in interface org.apache.openjpa.kernel.QueryContext
Scope of a mapping from the result data to its object representation.
getResultMappingScope() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getResultObject() - Method in class org.apache.openjpa.jdbc.kernel.GenericResultObjectProvider
 
getResultObject() - Method in class org.apache.openjpa.jdbc.kernel.InstanceResultObjectProvider
 
getResultObject() - Method in class org.apache.openjpa.jdbc.kernel.PagingResultObjectProvider
 
getResultObject() - Method in class org.apache.openjpa.kernel.AbstractPCResultObjectProvider
 
getResultObject() - Method in class org.apache.openjpa.lib.rop.ListResultObjectProvider
 
getResultObject() - Method in class org.apache.openjpa.lib.rop.MergedResultObjectProvider
 
getResultObject() - Method in class org.apache.openjpa.lib.rop.RangeResultObjectProvider
 
getResultObject() - Method in interface org.apache.openjpa.lib.rop.ResultObjectProvider
Instantiate the current result object.
getResults(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, int, Joins[], boolean) - Method in interface org.apache.openjpa.jdbc.meta.strats.LRSMapFieldStrategy
Return results containing all keys and values for this map.
getResults(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, int, Joins[], boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapInverseKeyFieldStrategy
 
getResults(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, int, Joins[], boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapTableFieldStrategy
 
getResults() - Method in interface org.apache.openjpa.lib.meta.MetaDataParser
Return the results from the last parse.
getResults() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
 
getResultSet() - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
Return the backing result set.
getResultSet() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getResultSet(boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
Get the last result set, with the option of not wrapping it in a DelegatingResultSet, which is the default.
getResultSet() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
getResultSet(boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
Get the last result set, with the option of not wrapping it in a DelegatingResultSet, which is the default.
getResultSet() - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
getResultSet(boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
Get the last result set, with the option of not wrapping it in a DelegatingResultSet, which is the default.
getResultSetConcurrency() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getResultSetConcurrency() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
getResultSetConcurrency() - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
getResultSetHoldability() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getResultSetHoldability() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getResultSetHoldability() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
getResultSetHoldability() - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
getResultSetInfo() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getResultSetInfo() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getResultSetInfo() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getResultSetType() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The JDBC result set type.
getResultSetType() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getResultSetType() - Method in class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
 
getResultSetType() - Method in interface org.apache.openjpa.jdbc.kernel.JDBCFetchConfiguration
The result set type to use as a constant from ResultSet.
getResultSetType() - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
getResultSetType() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getResultSetType() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
getResultSetType() - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
getResultSetType() - Method in interface org.apache.openjpa.persistence.jdbc.JDBCFetchPlan
Type of JDBC result set to use for query results.
getResultSetType() - Method in class org.apache.openjpa.persistence.jdbc.JDBCFetchPlanImpl
 
getResultSetTypeConstant() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Return the result set constant for the result set type.
getResultSetTypeConstant() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getResultType() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getResultType() - Method in interface org.apache.openjpa.kernel.QueryContext
Returns the result class that has been set through QueryContext.setResultType(java.lang.Class), or null if none.
getResultType() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getResultType() - Method in class org.apache.openjpa.meta.QueryMetaData
The query result class, or null if none.
getRetain() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager.RefCountConnection
 
getRetainState() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Whether to retain state after a transaction by default.
getRetainState() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getRetainState() - Method in interface org.apache.openjpa.kernel.Broker
Whether objects retain their persistent state on transaction commit.
getRetainState() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getRetainState() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getRetainState() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getRetainState() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether objects retain their persistent state on transaction commit.
getRetryClassRegistration() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Whether to warn and defer registration instead of throwing an exception when a registered persistent class cannot be processed.
getRetryClassRegistration() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getRollbackOnly() - Method in interface org.apache.openjpa.kernel.Broker
Return whether the current transaction has been marked for rollback.
getRollbackOnly() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getRollbackOnly() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getRollbackOnly() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getRollbackOnly() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return whether the current transaction has been marked for rollback.
getRootClasses() - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
getRootClasses() - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Root classes for recursive operations.
getRootClasses() - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
getRootInstances() - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
getRootInstances() - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Root instances for recursive operations.
getRootInstances() - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
getRow(OpenJPAStateManager, JDBCStore, RowManager, int) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Return the row to use for this field.
getRow(Table, int, OpenJPAStateManager, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy.CustomUpdate
 
getRow(Table, int, OpenJPAStateManager, boolean) - Method in interface org.apache.openjpa.jdbc.sql.RowManager
Return the row for the given table and owner object, or null if create is false and the row has not already been created.
getRow(Table, int, OpenJPAStateManager, boolean) - Method in class org.apache.openjpa.jdbc.sql.RowManagerImpl
 
getRow() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getSavepointManager() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The plugin to use for savepoint management.
getSavepointManager() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getSavepointManagerInstance() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Return the configured savepoint manager instance.
getSavepointManagerInstance() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getSAXParser(boolean, boolean) - Static method in class org.apache.openjpa.lib.xml.XMLFactory
Return a SAXParser with the specified configuration.
getSchema() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Default schema for unqualified tables.
getSchema() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getSchema(String) - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Return the schema with the given name, or null if none.
getSchema() - Method in class org.apache.openjpa.jdbc.schema.Sequence
Return the schema for the sequence.
getSchema() - Method in class org.apache.openjpa.jdbc.schema.Table
Return the schema for the table.
getSchemaAction() - Method in class org.apache.openjpa.jdbc.meta.MappingTool
The schema modification policy, or none.
getSchemaColumn() - Method in class org.apache.openjpa.jdbc.schema.TableSchemaFactory
The name of the schema column on the schema definition table.
getSchemaFactory() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The plugin string for the SchemaFactory to use to provide schema information during system initialization.
getSchemaFactory() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getSchemaFactoryInstance() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The SchemaFactory to use for schema information.
getSchemaFactoryInstance() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getSchemaGroup() - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Representation of the database schema.
getSchemaGroup() - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Return the schema group to use in mapping.
getSchemaGroup() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Return the schema group to reverse map.
getSchemaGroup() - Method in class org.apache.openjpa.jdbc.schema.Schema
Return the schema's group.
getSchemaGroup() - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Return the current schema group.
getSchemaGroup() - Method in interface org.apache.openjpa.jdbc.schema.SchemaParser
Return the current schema group.
getSchemaGroup() - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Return the schema group the tool will act on.
getSchemaGroup() - Method in class org.apache.openjpa.jdbc.schema.XMLSchemaParser
 
getSchemaName() - Method in class org.apache.openjpa.jdbc.schema.Column
The column's schema name.
getSchemaName() - Method in class org.apache.openjpa.jdbc.schema.Constraint
Return the column table's schema name.
getSchemaName() - Method in class org.apache.openjpa.jdbc.schema.Sequence
The sequence's schema name.
getSchemaName() - Method in class org.apache.openjpa.jdbc.schema.Table
The table's schema name.
getSchemaNameForMetadata(String) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Returns the schema name that will be used for obtaining information from DatabaseMetaData.
getSchemas() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Comma-separated list of modifiable schemas for persistent instances.
getSchemas() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getSchemas() - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Return all schemas.
getSchemas() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getSchemasList() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Modificable schema components.
getSchemasList() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getSchemaSource() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Implement to return the XML schema source for the document.
getSchemaSource() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
getSchemaTerm() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getSchemaTool() - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Return the schema tool to use for schema modification.
getSchemaWriter() - Method in class org.apache.openjpa.jdbc.meta.MappingTool
The stream to export the planned schema to as an XML document.
getScope() - Method in class org.apache.openjpa.lib.conf.Value
A class defining the scope in which this value is defined.
getScoreBeforeFieldName() - Method in class org.apache.openjpa.lib.util.CodeFormat
Whether to place an underscore before private field names.
getSearchStringEscape() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getSecondaryDeletes() - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy.CustomUpdate
 
getSecondaryDeletes() - Method in class org.apache.openjpa.jdbc.sql.RowManagerImpl
Return all deleted secondary rows.
getSecondaryRow(Table, int) - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy.CustomUpdate
 
getSecondaryRow(Table, int) - Method in interface org.apache.openjpa.jdbc.sql.RowManager
Return a row for the given secondary table.
getSecondaryRow(Table, int) - Method in class org.apache.openjpa.jdbc.sql.RowManagerImpl
 
getSecondaryTableJoinColumns(String) - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
Return any columns defined for the given class level join, or empty list if none.
getSecondaryTableName(String) - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
We allow fields to reference class-level joins using just the table name, whereas the class join might have schema, etc information.
getSecondaryTableNames() - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
Return the class-level joined tables.
getSecondaryUpdates() - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy.CustomUpdate
 
getSecondaryUpdates() - Method in class org.apache.openjpa.jdbc.sql.RowManagerImpl
Return all inserted and updated secondary rows.
getSelect() - Method in class org.apache.openjpa.jdbc.kernel.SelectResultObjectProvider
 
getSelect() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
Select for this result.
getSelectAliases() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getSelectAliases() - Method in interface org.apache.openjpa.jdbc.sql.Select
Return the aliases of all selected columns and all selected buffers, in the order they were selected.
getSelectAliases() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getSelectConstructor() - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
Use to create SQL select.
getSelectedOrderIndexes() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
Return the indexes of the data in the select clause this query is ordered by.
getSelectOperation(JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return the "SELECT" operation clause, adding any available hints, etc.
getSelectOperation(JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
Check to see if we have set the OracleDictionary.SELECT_HINT in the fetch configuraiton, and if so, append the Orache hint after the "SELECT" part of the query.
getSelects(Select, boolean, boolean) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return the portion of the select statement between the SELECT keyword and the FROM keyword.
getSelects() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
getSelects(Select, boolean, boolean) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
getSelects() - Method in interface org.apache.openjpa.jdbc.sql.Union
Return the selects that make up this union.
getSelectSubclasses() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
getSelectSubclasses() - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
Return the org.apache.openjpa.sql.Select subclasses constant for loading this relation, based on how the related type is mapped, whether this relation is polymorphic, and whether it is configured to use class criteria.
getSelectSubclasses() - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
getSequence() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Plugin string for the default system Seq.
getSequence() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getSequence() - Method in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
The sequence name.
getSequence(ClassMapping, Connection) - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
Return the current sequence value, or -1 if unattainable.
getSequence(String) - Method in class org.apache.openjpa.jdbc.schema.Schema
Return the sequence with the given name, or null if none.
getSequence() - Method in class org.apache.openjpa.meta.SequenceMetaData
Native sequence name.
getSequenceColumn() - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
The name of the column that holds the sequence value.
getSequenceColumn() - Method in class org.apache.openjpa.jdbc.meta.SequenceMapping
Name of sequence column, if any.
getSequenceFactory() - Method in class org.apache.openjpa.meta.SequenceMetaData
A factory to transform spec sequences produced by user factories into the OpenJPA sequence type.
getSequenceInstance() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The default system sequence.
getSequenceInstance() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getSequenceMetaData(String, ClassLoader, boolean) - Method in class org.apache.openjpa.meta.MetaDataRepository
Return sequence metadata for the given name and classloader.
getSequenceMetaDatas() - Method in class org.apache.openjpa.meta.MetaDataRepository
Return the cached sequence metadata.
getSequencePlugin() - Method in class org.apache.openjpa.meta.SequenceMetaData
Plugin string describing the Seq.
getSequences() - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Whether to manipulate sequences.
getSequences() - Method in class org.apache.openjpa.jdbc.schema.Schema
Return the schema's sequences.
getSequences() - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Return whether sequences should be generated.
getSequences() - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Whether sequences should be manipulated.
getSequences() - Method in class org.apache.openjpa.jdbc.schema.XMLSchemaSerializer
 
getSequences(DatabaseMetaData, String, String, String, Connection) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Reflect on the schema to find sequences matching the given name pattern.
getSequencesSQL(String, String) - Method in class org.apache.openjpa.jdbc.sql.DB2Dictionary
 
getSequencesSQL(String, String) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return the SQL needed to select the list of sequences.
getSequencesSQL(String, String) - Method in class org.apache.openjpa.jdbc.sql.HSQLDictionary
 
getSequencesSQL(String, String) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
getSequencesSQL(String, String) - Method in class org.apache.openjpa.jdbc.sql.PostgresDictionary
 
getSerializeAnnotations() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Whether to serialize content originally specified in annotations.
getSet(Column) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
Return the value set for update on the given column.
getSetter(Class, String) - Static method in class org.apache.openjpa.util.ImplHelper
Return the setter method matching the given property name.
getShort(int) - Method in interface org.apache.openjpa.enhance.DynamicStorage
Get the short at the given index.
getShort(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getShort(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getShort(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getShort(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getShort(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getShort(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.PostgresDictionary
 
getShort(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id.
getShort(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column.
getShort(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getShort(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getShort(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getShort(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getShortInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getShortInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getSingleResult() - Method in class org.apache.openjpa.persistence.QueryImpl
Execute a query that returns a single result.
getSize() - Method in class org.apache.openjpa.jdbc.schema.Column
Return the column's size.
getSoftReferenceSize() - Method in class org.apache.openjpa.datacache.ConcurrentDataCache
Returns the maximum number of unpinned objects to keep soft references to.
getSoftReferenceSize() - Method in class org.apache.openjpa.datacache.ConcurrentQueryCache
Returns the maximum number of unpinned objects to keep soft references to.
getSoftReferenceSize() - Method in class org.apache.openjpa.util.CacheMap
The maximum number of soft references to maintain, or -1 for no limit.
getSourceFile() - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
 
getSourceFile() - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping
 
getSourceFile() - Method in class org.apache.openjpa.jdbc.schema.Sequence
 
getSourceFile() - Method in class org.apache.openjpa.jdbc.schema.Table
 
getSourceFile() - Method in interface org.apache.openjpa.lib.meta.SourceTracker
Return the file from which this instance was parsed.
getSourceFile() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Return the file of the source being parsed.
getSourceFile(Object) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
Return the source file for the given instance.
getSourceFile(Class) - Static method in class org.apache.openjpa.lib.util.Files
Return the source file for the given class, or null if the source is not in the CLASSPATH.
getSourceFile(ClassMetaData) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Return the current source file of the given metadata.
getSourceFile(SequenceMetaData) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Return the current source file of the given metadata.
getSourceFile() - Method in class org.apache.openjpa.meta.ClassMetaData
 
getSourceFile() - Method in class org.apache.openjpa.meta.NonPersistentMetaData
 
getSourceFile() - Method in class org.apache.openjpa.meta.QueryMetaData
 
getSourceFile() - Method in class org.apache.openjpa.meta.SequenceMetaData
 
getSourceFile() - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Determine the source file we're parsing.
getSourceFile() - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
getSourceFile(Object) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Override to not overwrite annotations.
getSourceIsSystemId() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Whether to use the source name as the XML system id.
getSourceLocationMessage(SourceTracker[]) - Static method in class org.apache.openjpa.lib.meta.SourceTrackers
Create a message appropriate for display to the user describing the location(s) that trackers were loaded from.
getSourceMode() - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping
The source mode of this query result.
getSourceMode() - Method in class org.apache.openjpa.meta.ClassMetaData
The source mode this metadata has been loaded under.
getSourceMode() - Method in class org.apache.openjpa.meta.MetaDataRepository
The source mode determining what metadata to load.
getSourceMode() - Method in class org.apache.openjpa.meta.QueryMetaData
The source mode of this query.
getSourceName() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Return the name of the source file being parsed.
getSourceScope() - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
 
getSourceScope() - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping
 
getSourceScope() - Method in class org.apache.openjpa.jdbc.schema.Sequence
 
getSourceScope() - Method in class org.apache.openjpa.jdbc.schema.Table
 
getSourceScope() - Method in interface org.apache.openjpa.lib.meta.SourceTracker
Return the domain-dependent scope of this instance within its file.
getSourceScope() - Method in class org.apache.openjpa.meta.ClassMetaData
 
getSourceScope() - Method in class org.apache.openjpa.meta.NonPersistentMetaData
 
getSourceScope() - Method in class org.apache.openjpa.meta.QueryMetaData
 
getSourceScope() - Method in class org.apache.openjpa.meta.SequenceMetaData
 
getSourceScope() - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
getSourceType() - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
 
getSourceType() - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping
 
getSourceType() - Method in class org.apache.openjpa.jdbc.schema.Sequence
 
getSourceType() - Method in class org.apache.openjpa.jdbc.schema.Table
 
getSourceType() - Method in interface org.apache.openjpa.lib.meta.SourceTracker
Return the type of source.
getSourceType() - Method in class org.apache.openjpa.meta.ClassMetaData
 
getSourceType() - Method in class org.apache.openjpa.meta.NonPersistentMetaData
 
getSourceType() - Method in class org.apache.openjpa.meta.QueryMetaData
 
getSourceType() - Method in class org.apache.openjpa.meta.SequenceMetaData
 
getSourceType() - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
getSpaceBeforeParen() - Method in class org.apache.openjpa.lib.util.CodeFormat
Whether to place a space before parentheses.
getSpaceInParen() - Method in class org.apache.openjpa.lib.util.CodeFormat
Whether to place a space within parentheses.
getSpecification() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
A configuration can be set with defaults for a specific specification.
getSpecification() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getSQL() - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy.CustomUpdate
Return a boolean SQL expression that should be added to the WHERE clause of an UPDATE to test whether the current database record matches our stored version.
getSQL(DBDictionary) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
Return the SQL for the operation on this row.
getSQL() - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Return the SQL for this buffer.
getSQL(boolean) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Returns the SQL for this buffer.
getSQL() - Method in class org.apache.openjpa.lib.jdbc.JDBCEvent
Return the SQL associated with this event; may be null.
getSQLFactory() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The SQL factory to use for SQL constructs.
getSQLFactory() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getSQLFactory() - Method in interface org.apache.openjpa.jdbc.kernel.JDBCStore
Return the SQL factory for this runtime.
getSQLFactory() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
getSQLFactoryInstance() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The SQL factory to use for SQL constructs.
getSQLFactoryInstance() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getSQLKeywords() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getSQLLog() - Method in class org.apache.openjpa.lib.jdbc.DataSourceLogs
The log to write SQL messages to.
getSQLObject(Object, Map) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getSQLObject(Column, Map, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getSQLObject(Object, Map) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getSQLObject(Column, Map, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getSQLObject(Object, Map) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id; may not be supported by results that are not backed by a SQL result set.
getSQLObject(Column, Map, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column; may not be supported by results that are not backed by a SQL result set.
getSQLObjectInternal(Object, Map, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getSQLObjectInternal(Object, Map, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getSQLState() - Method in exception org.apache.openjpa.lib.jdbc.ReportingSQLException
Returns the SQL state of the underlying SQLException.
getSQLStateType() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getSQLValue() - Method in interface org.apache.openjpa.jdbc.kernel.exps.FilterValue
If this is a constant, returns its value as it would be represented in the database in this context, else return null.
getStackTrace(Throwable) - Static method in class org.apache.openjpa.lib.log.AbstractLog
Utility method to obtain a stack trace as a String.
getStartIndex() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getStartIndex() - Method in interface org.apache.openjpa.jdbc.sql.Select
The result start index.
getStartIndex() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getStartRange() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getStartRange() - Method in interface org.apache.openjpa.kernel.QueryContext
Return the 0-based start index for the returned results.
getStartRange() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getStateManager(Object, StoreContext) - Static method in class org.apache.openjpa.jdbc.meta.strats.RelationStrategies
Return the state manager for the given instance, using a detached state manager if the instnace is not managed.
getStateManager(Object) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getStateManager(Object) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getStateManager(Object) - Method in interface org.apache.openjpa.kernel.StoreContext
Return the state manager for the given instance.
getStateManagerImpl(Object, boolean) - Method in class org.apache.openjpa.kernel.BrokerImpl
Return the state manager for the given instance, or null.
getStateManagerImplById(Object, boolean) - Method in class org.apache.openjpa.kernel.BrokerImpl
Return the state manager for the given oid.
getStatement() - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
Return the statement that produced this result.
getStatement() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getStatement() - Method in class org.apache.openjpa.lib.jdbc.JDBCEvent
Return the Statement for this event, may be null for events unrelated to Statement execution.
getStatement() - Method in exception org.apache.openjpa.lib.jdbc.ReportingSQLException
Returns the Statement that caused the exception.
getStates() - Method in class org.apache.openjpa.kernel.OpenJPASavepoint
Return the map of states to savepoint data.
getStatus(ClassMapping) - Method in class org.apache.openjpa.jdbc.kernel.ClassTableJDBCSeq
 
getStatus(ClassMapping) - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
Return the appropriate status object for the given class, or null if cannot handle the given class.
getStorageGenerator() - Method in interface org.apache.openjpa.enhance.PCDataGenerator.DynamicPCData
 
getStore() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreQuery
Return the store.
getStore() - Method in class org.apache.openjpa.jdbc.kernel.SelectResultObjectProvider
 
getStore() - Method in class org.apache.openjpa.jdbc.kernel.SQLStoreQuery
 
getStore() - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
Optional store manager used to deserialize blobs containing references to persistent objects.
getStore(SQLException) - Static method in class org.apache.openjpa.jdbc.sql.SQLExceptions
Convert the specified exception into a StoreException.
getStore(SQLException, Object) - Static method in class org.apache.openjpa.jdbc.sql.SQLExceptions
Convert the specified exception into a OpenJPAException.
getStore(SQLException, DBDictionary) - Static method in class org.apache.openjpa.jdbc.sql.SQLExceptions
Convert the specified exception into a StoreException.
getStore(SQLException, Object, DBDictionary) - Static method in class org.apache.openjpa.jdbc.sql.SQLExceptions
Convert the specified exception into a StoreException.
getStore(Localizer.Message, SQLException, DBDictionary) - Static method in class org.apache.openjpa.jdbc.sql.SQLExceptions
Convert the specified exception into a StoreException.
getStore(String, SQLException, DBDictionary) - Static method in class org.apache.openjpa.jdbc.sql.SQLExceptions
Convert the specified exception into a StoreException.
getStore(String, SQLException, Object, DBDictionary) - Static method in class org.apache.openjpa.jdbc.sql.SQLExceptions
Convert the specified exception into a StoreException.
getStore() - Method in class org.apache.openjpa.xmlstore.XMLConfiguration
Return the XMLStore associated with this configuration.
getStoreCache() - Method in class org.apache.openjpa.persistence.EntityManagerFactoryImpl
 
getStoreCache(String) - Method in class org.apache.openjpa.persistence.EntityManagerFactoryImpl
 
getStoreCache() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManagerFactory
Access the level 2 store cache.
getStoreCache(String) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManagerFactory
Access a named level 2 store cache.
getStoreContext() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getStoreContext() - Method in interface org.apache.openjpa.kernel.QueryContext
The persistence context for the query.
getStoreContext() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getStoreEnumOrdinal() - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Whether to store enums as the ordinal value rather than the enum name.
getStoreFacadeTypeRegistry() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Return the StoreFacadeTypeRegistry instance associated with this configuration.
getStoreFacadeTypeRegistry() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getStoreManager() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getStoreManager() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getStoreManager() - Method in interface org.apache.openjpa.kernel.StoreContext
Return the store manager in use.
getStoreOrdinal() - Method in class org.apache.openjpa.jdbc.meta.strats.EnumValueHandler
Whether to store the enum value as its ordinal.
getStoreQuery() - Method in class org.apache.openjpa.kernel.QueryImpl
Internal store query.
getStoreUnmappedObjectIdString() - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Whether to store a relation to an unmapped class by stringifying the oid of the related object, rather than storing primary key values.
getStrategy() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
The strategy used to map this mapping.
getStrategy() - Method in class org.apache.openjpa.jdbc.meta.Discriminator
The strategy used for class discrimination.
getStrategy() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
The strategy used to map this mapping.
getStrategy(ClassMapping, boolean) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Default mapping strategy when there is no explicit strategy and no hierarchy strategy given.
getStrategy(Version, boolean) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Default version mapping strategy when there is no explicit strategy.
getStrategy(Discriminator, boolean) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Default discriminator mapping strategy when there is no explicit strategy.
getStrategy(ValueMapping, Class, boolean) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Custom handler or strategy for the given field, or null if none has been registered.
getStrategy(ClassMapping, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
getStrategy(Version, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
getStrategy(Discriminator, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
getStrategy(ValueMapping, Class, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
getStrategy() - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Mapping strategy name.
getStrategy(ClassMapping, boolean) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
getStrategy(Version, boolean) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
getStrategy(Discriminator, boolean) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
getStrategy(ValueMapping, Class, boolean) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
getStrategy() - Method in class org.apache.openjpa.jdbc.meta.Version
The strategy used for versioning.
getStrategy(Version, boolean) - Method in class org.apache.openjpa.persistence.jdbc.PersistenceMappingDefaults
 
getStrategy(Discriminator, boolean) - Method in class org.apache.openjpa.persistence.jdbc.PersistenceMappingDefaults
 
getStrategy(FieldMetaData) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer
 
getStrategy(FieldMetaData) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Return the serialized strategy name.
getStrategyInstaller() - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Installs mapping strategies on components.
getStream() - Method in class org.apache.openjpa.lib.log.LogFactoryImpl
The stream to write to.
getStrictIdentityValues() - Method in class org.apache.openjpa.conf.Compatibility
Whether to require exact identity value types when creating object ids from a class and value.
getString(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getString(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getString(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getString(ResultSet, int) - Method in class org.apache.openjpa.jdbc.sql.FoxProDictionary
 
getString(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getString(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getString(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id.
getString(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column.
getString() - Method in class org.apache.openjpa.lib.conf.PluginListValue
Override to recognize aliases of the class name without the attached properties string.
getString() - Method in class org.apache.openjpa.lib.conf.PluginValue
 
getString() - Method in class org.apache.openjpa.lib.conf.Value
Return a stringified version of this value.
getString(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getString(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getString(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getString(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getStringExtension(String) - Method in class org.apache.openjpa.meta.Extensions
Get the value as a string.
getStringExtension(String, String) - Method in class org.apache.openjpa.meta.Extensions
Get the value as a string.
getStringFunctions() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getStringInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getStringInternal(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getSubclasses() - Method in class org.apache.openjpa.jdbc.sql.Join
If joining a relation, how to deal with subclasses.
getSubclassesLoaded() - Method in class org.apache.openjpa.jdbc.meta.Discriminator
Whether this Discriminator has loaded subclasses yet.
getSubclassFetchMode() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Specifies the default subclass fetch mode to use.
getSubclassFetchMode() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getSubclassFetchMode() - Method in class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
 
getSubclassFetchMode(ClassMapping) - Method in class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
 
getSubclassFetchMode() - Method in interface org.apache.openjpa.jdbc.kernel.JDBCFetchConfiguration
Return the subclass fetch mode.
getSubclassFetchMode(ClassMapping) - Method in interface org.apache.openjpa.jdbc.kernel.JDBCFetchConfiguration
Return the effective subclass fetch mode for the given type.
getSubclassFetchMode() - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
getSubclassFetchMode(ClassMapping) - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
getSubclassFetchMode() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
The subclass fetch mode, as one of the eager constants in JDBCFetchConfiguration.
getSubclassFetchMode() - Method in interface org.apache.openjpa.persistence.jdbc.JDBCFetchPlan
Eager fetch mode in loading subclasses.
getSubclassFetchMode() - Method in class org.apache.openjpa.persistence.jdbc.JDBCFetchPlanImpl
 
getSubclassFetchModeConstant() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Return the subclass fetch mode as one of the following symbolic constants: EagerFetchModes.EAGER_NONE EagerFetchModes.EAGER_JOIN EagerFetchModes.EAGER_PARALLEL
getSubclassFetchModeConstant() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getSubclassStrategy() - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default subclass strategy alias.
getSubselectPath() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getSubselectPath() - Method in interface org.apache.openjpa.jdbc.sql.Select
Return the subselect path for this select, if it is a subselect.
getSubselectPath() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getSubselects() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getSubselects() - Method in interface org.apache.openjpa.jdbc.sql.Select
Return this select's subselects, or empty collection if none.
getSubselects() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getSubstitutions() - Method in class org.apache.openjpa.lib.util.Localizer.Message
Substitutions inserted into the message.
getSubtype() - Method in exception org.apache.openjpa.persistence.ArgumentException
 
getSubtype() - Method in exception org.apache.openjpa.persistence.EntityExistsException
 
getSubtype() - Method in exception org.apache.openjpa.persistence.EntityNotFoundException
 
getSubtype() - Method in exception org.apache.openjpa.persistence.InvalidStateException
 
getSubtype() - Method in exception org.apache.openjpa.persistence.NonUniqueResultException
 
getSubtype() - Method in exception org.apache.openjpa.persistence.NoResultException
 
getSubtype() - Method in exception org.apache.openjpa.persistence.OptimisticLockException
 
getSubtype() - Method in exception org.apache.openjpa.persistence.PersistenceException
 
getSubtype() - Method in exception org.apache.openjpa.persistence.RollbackException
 
getSubtype() - Method in exception org.apache.openjpa.persistence.TransactionRequiredException
 
getSubtype() - Method in exception org.apache.openjpa.util.CallbackException
 
getSubtype() - Method in interface org.apache.openjpa.util.ExceptionInfo
Exception subtype.
getSubtype() - Method in exception org.apache.openjpa.util.InvalidStateException
 
getSubtype() - Method in exception org.apache.openjpa.util.LockException
 
getSubtype() - Method in exception org.apache.openjpa.util.MetaDataException
 
getSubtype() - Method in exception org.apache.openjpa.util.NoTransactionException
 
getSubtype() - Method in exception org.apache.openjpa.util.ObjectExistsException
 
getSubtype() - Method in exception org.apache.openjpa.util.ObjectNotFoundException
 
getSubtype() - Method in exception org.apache.openjpa.util.OpenJPAException
Exception subtype.
getSubtype() - Method in exception org.apache.openjpa.util.OptimisticException
 
getSubtype() - Method in exception org.apache.openjpa.util.ReferentialIntegrityException
 
getSuffix() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Expected suffix for metadata resources, or null if unknown.
getSuperclassField(FieldMetaData) - Method in class org.apache.openjpa.meta.ClassMetaData
Return the superclass copy of the given field.
getSuperclassJoin(ClassMapping, Table, boolean) - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
Return the join from this class to its superclass.
getSuperTables(String, String, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getSuperTypes(String, String, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getSynchronization() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getSynchronizeMappings() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Whether OpenJPA should try to automatically refresh O/R mapping information and the database schema.
getSynchronizeMappings() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getSyncMappingInfo() - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer
Whether to automatically synchronize mapping info with data available from mapped components before serialization.
getSyncWithManagedTransactions() - Method in interface org.apache.openjpa.kernel.Broker
Whether to check for a global transaction upon every managed, non-transactional operation.
getSyncWithManagedTransactions() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getSyncWithManagedTransactions() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getSyncWithManagedTransactions() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getSyncWithManagedTransactions() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether to check for a global transaction upon every managed, non-transactional operation.
getSystemDataCache() - Method in interface org.apache.openjpa.datacache.DataCacheManager
Return the system-wide data cache, or null if caching is not enabled.
getSystemDataCache() - Method in class org.apache.openjpa.datacache.DataCacheManagerImpl
 
getSystemFunctions() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getSystemListeners() - Method in class org.apache.openjpa.meta.MetaDataRepository
Return the system lifecycle listeners
getSystemQueryCache() - Method in interface org.apache.openjpa.datacache.DataCacheManager
Return the system query cache, or null if not configured.
getSystemQueryCache() - Method in class org.apache.openjpa.datacache.DataCacheManagerImpl
 
getTab() - Method in class org.apache.openjpa.lib.util.CodeFormat
Tab string.
getTab(int) - Method in class org.apache.openjpa.lib.util.CodeFormat
Tab string.
getTable() - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
The sequence table name.
getTable() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
The mapping's primary table.
getTable(ClassMapping, boolean) - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
Return the table for the given class.
getTable() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
The mapping's primary table.
getTable(FieldMapping, boolean, boolean) - Method in class org.apache.openjpa.jdbc.meta.FieldMappingInfo
Return the table for the given field, or null if no table given.
getTable() - Method in class org.apache.openjpa.jdbc.meta.SequenceMapping
Name of sequence table, if any.
getTable() - Method in class org.apache.openjpa.jdbc.schema.Column
Return the table for the column.
getTable() - Method in class org.apache.openjpa.jdbc.schema.Constraint
Return the table of this constraint.
getTable(String) - Method in class org.apache.openjpa.jdbc.schema.Schema
Return the table with the given name, or null if none.
getTable() - Method in class org.apache.openjpa.jdbc.schema.TableSchemaFactory
The name of the schema definition table.
getTable() - Method in interface org.apache.openjpa.jdbc.sql.Row
Return the table for this row.
getTable() - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
getTable1() - Method in class org.apache.openjpa.jdbc.sql.Join
 
getTable2() - Method in class org.apache.openjpa.jdbc.sql.Join
 
getTableAliases() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getTableAliases() - Method in interface org.apache.openjpa.jdbc.sql.Select
Return the set of all used table aliases.
getTableAliases() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getTableName() - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
The given table name.
getTableName() - Method in class org.apache.openjpa.jdbc.meta.FieldMappingInfo
The user-supplied name of the table for this field.
getTableName(ClassMapping, Schema) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Return the default table name for the given class.
getTableName(FieldMapping, Schema) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Return the default secondary table name for the given field.
getTableName(ClassMapping, Schema) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
getTableName(FieldMapping, Schema) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
getTableName(ClassMapping, Schema) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
getTableName(FieldMapping, Schema) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
getTableName() - Method in class org.apache.openjpa.jdbc.schema.Column
The column's table name.
getTableName() - Method in class org.apache.openjpa.jdbc.schema.Constraint
Return the column's table name.
getTableName(ClassMapping, Schema) - Method in class org.apache.openjpa.persistence.jdbc.PersistenceMappingDefaults
 
getTableName(FieldMapping, Schema) - Method in class org.apache.openjpa.persistence.jdbc.PersistenceMappingDefaults
 
getTableNameForMetadata(String) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Returns the table name that will be used for obtaining information from DatabaseMetaData.
getTableNameForMetadata(String) - Method in class org.apache.openjpa.jdbc.sql.InterbaseDictionary
 
getTablePrivileges(String, String, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getTables() - Method in class org.apache.openjpa.jdbc.schema.Schema
Return the schema's tables.
getTables() - Method in interface org.apache.openjpa.jdbc.schema.SchemaSerializer
Return the set of tables that will be serialized.
getTables() - Method in class org.apache.openjpa.jdbc.schema.XMLSchemaSerializer
 
getTables(DatabaseMetaData, String, String, String, Connection) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Reflect on the schema to find tables matching the given name pattern.
getTables(String, String, String, String[]) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getTableType(Table, int) - Method in class org.apache.openjpa.jdbc.meta.PropertiesReverseCustomizer
 
getTableType(Table, int) - Method in interface org.apache.openjpa.jdbc.meta.ReverseCustomizer
Return the type of the given table, or the given default type.
getTableTypes() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getTabSpaces() - Method in class org.apache.openjpa.lib.util.CodeFormat
The number of spaces to use for tabs; 0 means to use actual tab characters.
getTag() - Method in class org.apache.openjpa.jdbc.kernel.exps.GetColumn
 
getTag() - Method in class org.apache.openjpa.jdbc.kernel.exps.SQLEmbed
 
getTag() - Method in class org.apache.openjpa.jdbc.kernel.exps.SQLExpression
Deprecated.  
getTag() - Method in class org.apache.openjpa.jdbc.kernel.exps.SQLValue
Deprecated.  
getTag() - Method in interface org.apache.openjpa.kernel.exps.AggregateListener
Return the tag that this listener listens for.
getTag() - Method in interface org.apache.openjpa.kernel.exps.FilterListener
Return the tag that this extension listens for.
getTag() - Method in class org.apache.openjpa.kernel.exps.StringContains
Deprecated.  
getTag() - Method in class org.apache.openjpa.kernel.exps.WildcardMatch
Deprecated.  
getTarget() - Method in class org.apache.openjpa.jdbc.schema.Column
The name of the column this column joins to, if any.
getTargetField() - Method in class org.apache.openjpa.jdbc.schema.Column
The name of the field this column joins to, if any.
getThis() - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
getThis() - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return a value representing this.
getThis() - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
getThrowsDec(int) - Method in class org.apache.openjpa.lib.util.CodeFormat
Throws declaration.
getTime(Object, Calendar) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getTime(Column, Calendar, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getTime(ResultSet, int, Calendar) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getTime(Object, Calendar) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getTime(Column, Calendar, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getTime(Object, Calendar) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id; may not be supported by results that are not backed by a SQL result set.
getTime(Column, Calendar, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column; may not be supported by results that are not backed by a SQL result set.
getTime(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getTime(int, Calendar) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getTime(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getTime(String, Calendar) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getTime(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getTime(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getTime(int, Calendar) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getTime(String, Calendar) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getTime() - Method in class org.apache.openjpa.lib.jdbc.JDBCEvent
Return the time the event was constructed.
getTimeDateFunctions() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getTimeInternal(Object, Calendar, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getTimeInternal(Object, Calendar, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getTimeout() - Method in class org.apache.openjpa.datacache.QueryKey
Return the amount of time this key is good for.
getTimeout() - Method in exception org.apache.openjpa.util.LockException
The number of milliseconds to wait for a lock.
getTimeoutTime() - Method in class org.apache.openjpa.datacache.QueryResult
Expiration time, or -1 for no timeout.
getTimestamp(Object, Calendar) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getTimestamp(Column, Calendar, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getTimestamp(ResultSet, int, Calendar) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Convert the specified column of the SQL ResultSet to the proper java type.
getTimestamp(Object, Calendar) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getTimestamp(Column, Calendar, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
getTimestamp(ResultSet, int, Calendar) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
getTimestamp(Object, Calendar) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column or id; may not be supported by results that are not backed by a SQL result set.
getTimestamp(Column, Calendar, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the value stored in the given column; may not be supported by results that are not backed by a SQL result set.
getTimestamp(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getTimestamp(int, Calendar) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getTimestamp(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getTimestamp(String, Calendar) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getTimestamp(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getTimestamp(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getTimestamp(int, Calendar) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getTimestamp(String, Calendar) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getTimestampInternal(Object, Calendar, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
getTimestampInternal(Object, Calendar, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
getToken() - Method in class org.apache.openjpa.enhance.ApplicationIdTool
The token to use to separate stringified primary key field values.
getTotal() - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator.Event
 
getTrackChanges() - Method in class org.apache.openjpa.util.ProxyManagerImpl
Whether proxies produced by this factory will use ChangeTrackers to try to cut down on data store operations at the cost of some extra bookkeeping overhead.
getTrackKeys() - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
getTrackKeys() - Method in interface org.apache.openjpa.util.MapChangeTracker
Whether to track keys or values.
getTrackKeys() - Method in class org.apache.openjpa.util.MapChangeTrackerImpl
 
getTrackParameters() - Method in class org.apache.openjpa.lib.jdbc.LoggingConnectionDecorator
Whether to track parameters for the purposes of reporting exceptions.
getTransaction() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getTransactionalObjects() - Method in class org.apache.openjpa.event.TransactionEvent
Return the unmodifiable set of persistence capable objects participating in the transaction.
getTransactionalObjects() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getTransactionalObjects() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getTransactionalObjects() - Method in interface org.apache.openjpa.kernel.StoreContext
Return a list of current transaction instances.
getTransactionalObjects() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getTransactionalObjects() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return a set of current transaction instances.
getTransactionalStates() - Method in class org.apache.openjpa.kernel.BrokerImpl
Return a copy of all transactional state managers.
getTransactionIsolation() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The transaction isolation level to use at the database level.
getTransactionIsolation() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getTransactionIsolation() - Method in class org.apache.openjpa.lib.jdbc.ConfiguringConnectionDecorator
The transaction isolation level.
getTransactionIsolation() - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
getTransactionIsolationConstant() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Return the proper transaction isolation level constant from Connection, or -1 for the default level.
getTransactionIsolationConstant() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getTransactionListenerCallbackMode() - Method in interface org.apache.openjpa.kernel.Broker
The callback mode for handling exceptions from transaction event listeners.
getTransactionListenerCallbackMode() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getTransactionListenerCallbackMode() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getTransactionListenerCallbackMode() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getTransactionListenerCallbackMode() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
The CallbackModes flags for handling transaction listener exceptions.
getTransactionManager() - Method in class org.apache.openjpa.ee.AutomaticManagedRuntime
 
getTransactionManager() - Method in class org.apache.openjpa.ee.InvocationManagedRuntime
 
getTransactionManager() - Method in class org.apache.openjpa.ee.JNDIManagedRuntime
 
getTransactionManager() - Method in interface org.apache.openjpa.ee.ManagedRuntime
Return the TransactionManager for the managed runtime.
getTransactionManager() - Method in class org.apache.openjpa.ee.SunOneManagedRuntime
 
getTransactionManager() - Method in class org.apache.openjpa.ee.WASManagedRuntime
Gets an extendedJTATransaction from JNDI and creates a transaction wrapper
getTransactionManager() - Method in class org.apache.openjpa.ee.WLSManagedRuntime
 
getTransactionManagerMethod() - Method in class org.apache.openjpa.ee.InvocationManagedRuntime
Return the method to invoke to get the TransactionManager.
getTransactionManagerName() - Method in class org.apache.openjpa.ee.JNDIManagedRuntime
Return the location of the TransactionManager in JNDI.
getTransactionMode() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Specifies the behavior of the transaction model.
getTransactionMode() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getTransactionType() - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
getTransmitPersistedObjectIds() - Method in class org.apache.openjpa.conf.RemoteCommitProviderValue
Whether to transmit persisted object ids in remote commit events.
getTransmitPersistedObjectIds() - Method in class org.apache.openjpa.event.RemoteCommitEventManager
Whether the oids of added instances will be transmitted.
getType() - Method in class org.apache.openjpa.enhance.ApplicationIdTool
Return the type we are generating an application id for.
getType() - Method in class org.apache.openjpa.enhance.CodeGenerator
Return the type being generated.
getType(ClassMetaData) - Method in class org.apache.openjpa.enhance.PCEnhancer
Return the concrete type for the given class, i.e.
getType() - Method in class org.apache.openjpa.event.LifecycleEvent
Return the event type.
getType() - Method in class org.apache.openjpa.event.TransactionEvent
Return the type of event.
getType() - Method in class org.apache.openjpa.jdbc.conf.JDBCProductDerivation
 
getType() - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
 
getType() - Method in interface org.apache.openjpa.jdbc.kernel.exps.FilterValue
Return the expected type of this value.
getType(Class, Class[]) - Method in class org.apache.openjpa.jdbc.kernel.exps.GetColumn
 
getType(Class, Class[]) - Method in class org.apache.openjpa.jdbc.kernel.exps.SQLEmbed
 
getType() - Method in class org.apache.openjpa.jdbc.schema.Column
Return the column's SQL type.
getType() - Method in class org.apache.openjpa.jdbc.sql.Join
 
getType(Class[]) - Method in interface org.apache.openjpa.kernel.exps.AggregateListener
Return the expected type of the result of this listener.
getType(Class, Class[]) - Method in interface org.apache.openjpa.kernel.exps.FilterListener
Return the expected type of the result of this listener.
getType(Class, Class[]) - Method in class org.apache.openjpa.kernel.exps.StringContains
Deprecated.  
getType() - Method in interface org.apache.openjpa.kernel.exps.Value
Return the expected type for this value, or Object if the type is unknown.
getType(Class, Class[]) - Method in class org.apache.openjpa.kernel.exps.WildcardMatch
Deprecated.  
getType() - Method in interface org.apache.openjpa.kernel.PCData
Return the type of this instance.
getType() - Method in class org.apache.openjpa.kernel.PCDataImpl
 
getType() - Method in interface org.apache.openjpa.lib.conf.ProductDerivation
Return the type of derivation.
getType() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getType() - Method in class org.apache.openjpa.lib.jdbc.JDBCEvent
Return the event's type code.
getType() - Method in class org.apache.openjpa.meta.FieldMetaData
 
getType() - Method in class org.apache.openjpa.meta.NonPersistentMetaData
The type of metadata.
getType() - Method in class org.apache.openjpa.meta.SequenceMetaData
The sequence type.
getType() - Method in interface org.apache.openjpa.meta.ValueMetaData
The value class.
getType() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
getType() - Method in exception org.apache.openjpa.persistence.ArgumentException
 
getType() - Method in exception org.apache.openjpa.persistence.EntityExistsException
 
getType() - Method in exception org.apache.openjpa.persistence.EntityNotFoundException
 
getType() - Method in exception org.apache.openjpa.persistence.InvalidStateException
 
getType() - Method in class org.apache.openjpa.persistence.jdbc.JDBCPersistenceProductDerivation
 
getType() - Method in exception org.apache.openjpa.persistence.NonUniqueResultException
 
getType() - Method in exception org.apache.openjpa.persistence.NoResultException
 
getType() - Method in exception org.apache.openjpa.persistence.OptimisticLockException
 
getType() - Method in exception org.apache.openjpa.persistence.PersistenceException
 
getType() - Method in class org.apache.openjpa.persistence.PersistenceProductDerivation
 
getType() - Method in exception org.apache.openjpa.persistence.RollbackException
 
getType() - Method in exception org.apache.openjpa.persistence.TransactionRequiredException
 
getType() - Method in interface org.apache.openjpa.util.ExceptionInfo
Exception type.
getType() - Method in exception org.apache.openjpa.util.GeneralException
 
getType() - Method in exception org.apache.openjpa.util.InternalException
 
getType() - Method in exception org.apache.openjpa.util.OpenJPAException
Exception type.
getType() - Method in class org.apache.openjpa.util.OpenJPAId
Return the persitent class which this id instance represents.
getType() - Method in exception org.apache.openjpa.util.StoreException
 
getType() - Method in exception org.apache.openjpa.util.UnsupportedException
 
getType() - Method in exception org.apache.openjpa.util.UserException
 
getTypeAlias(Class) - Static method in class org.apache.openjpa.enhance.PCRegistry
Return the alias for the given type.
getTypeAlias() - Method in class org.apache.openjpa.meta.ClassMetaData
Returns the alias for the described type, or null if none has been set.
getTypeCode() - Method in class org.apache.openjpa.meta.FieldMetaData
 
getTypeCode(Class) - Static method in class org.apache.openjpa.meta.JavaTypes
Return the field metadata type code for the given class.
getTypeCode() - Method in interface org.apache.openjpa.meta.ValueMetaData
The type code of the value class.
getTypeCode() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
getTypeInfo() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getTypeJoin(ValueMapping, String, boolean, boolean) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingInfo
Return the join from this value to its related type.
getTypeMap() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Map of JDBC-name to Java-type-name entries that allows customization of reverse mapping columns to field types.
getTypeMap() - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
getTypeMapping() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
getTypeMapping() - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
Convenience method to perform cast from ValueMetaData.getTypeMetaData().
getTypeMapping() - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
getTypeMetaData() - Method in class org.apache.openjpa.meta.FieldMetaData
 
getTypeMetaData() - Method in interface org.apache.openjpa.meta.ValueMetaData
The metadata for the value class, if the type is persistent.
getTypeMetaData() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
getTypeName() - Method in class org.apache.openjpa.jdbc.schema.Column
The database-specific SQL type of this column.
getTypeName(Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return the preferred database type name for the given column's type from Types.
getTypeName(int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Returns the type name for the specific constant as defined by Types.
getTypeOverride() - Method in class org.apache.openjpa.meta.FieldMetaData
 
getTypeOverride() - Method in interface org.apache.openjpa.meta.ValueMetaData
User-supplied type overriding assumed type based on field.
getTypeOverride() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
getTypes() - Method in class org.apache.openjpa.datacache.TypesChangedEvent
Return the expired types.
getTypes() - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
 
getUDTs(String, String, String, int[]) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getUnicodeStream(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getUnicodeStream(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getUnimplementedExceptionType() - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
 
getUnimplementedExceptionType() - Method in interface org.apache.openjpa.meta.MetaDataDefaults
Return a runtime exception class to throw for un-implemented managed interface methods.
getUnimplementedExceptionType() - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
getUnique(ValueMapping, String, Table, Column[]) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Return a default constraint for the value, or null if the value columns should not be constrained by default.
getUnique(ValueMapping, String, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
getUnique() - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Raw unique constraint information.
getUnique(ValueMapping, String, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
getUnique(ValueMapping, String, boolean) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingInfo
Return a unique constraint for the given columns, or null if none.
getUnique(String) - Method in class org.apache.openjpa.jdbc.schema.Table
Return the unique constraint with the given name, or null if none.
getUniqueConstraintSQL(Unique) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return the declaration SQL for the given unique constraint.
getUniqueForeignKey(Table) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
If the given table has a single unique foreign key or a foreign key that matches the primary key, return it.
getUniqueName(Class) - Method in class org.apache.openjpa.datacache.DataCachePCDataGenerator
 
getUniqueName(Class) - Method in class org.apache.openjpa.enhance.PCDataGenerator
Creates a unique name for the given type's pcdata implementation.
getUniques() - Method in class org.apache.openjpa.jdbc.schema.Table
Return the table's unique constraints.
getUnloaded(FetchConfiguration) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
getUnloaded(FetchConfiguration) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
getUnloaded(FetchConfiguration) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
getUnloaded(FetchConfiguration) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return a mutable mask of the unloaded fields that need loading based on the given fetch configuration.
getUnloaded(FetchConfiguration) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
getUnsupportedOptions() - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
Returns a set of option names that this store manager does not support.
getUnsupportedOptions() - Method in class org.apache.openjpa.xmlstore.XMLStoreManager
 
getUpdateAction() - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Return the update action for the key.
getUpdateCount() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getUpdateCount() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
getUpdateCount() - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
getUpdatedClasses() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getUpdatedClasses() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return the set of classes for objects that have been modified in the current transaction.
getUpdatedObjectIds() - Method in class org.apache.openjpa.event.RemoteCommitEvent
When the event type is not PAYLOAD_EXTENTS, return the set of object IDs for updated objects.
getUpdatedTypeNames() - Method in class org.apache.openjpa.event.RemoteCommitEvent
When the event type is PAYLOAD_EXTENTS, return the set of class names for the classes of updated objects.
getUpdatedTypes() - Method in class org.apache.openjpa.event.TransactionEvent
Return the unmodifiable the set of classes of persistence capable objects that were modified in the transaction.
getUpdatedTypes() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getUpdatedTypes() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getUpdatedTypes() - Method in interface org.apache.openjpa.kernel.StoreContext
Return the set of classes for objects that have been modified in the current transaction.
getUpdateFields(OpenJPAStateManager) - Static method in class org.apache.openjpa.util.ImplHelper
Returns the fields of the state that require an update.
getUpdateManager() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The UpdateManager to use for managing SQL updates.
getUpdateManager() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getUpdateManagerInstance() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The UpdateManager for runtime data store interaction.
getUpdateManagerInstance() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
getUpdates() - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy.CustomUpdate
 
getUpdates() - Method in class org.apache.openjpa.jdbc.sql.RowManagerImpl
Return all updated primary rows.
getUpdates(StoreQuery) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery.AbstractExecutor
 
getUpdates() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
getUpdates() - Method in interface org.apache.openjpa.kernel.QueryContext
If this query is a bulk update, return a map of the FieldMetaDatas to Constants.
getUpdates() - Method in class org.apache.openjpa.kernel.QueryImpl
 
getUpdates(StoreQuery) - Method in interface org.apache.openjpa.kernel.StoreQuery.Executor
Return a map of FieldMetaData to update Constants, in cases where this query is for a bulk update.
getUpdateStrategy() - Method in class org.apache.openjpa.meta.FieldMetaData
The strategy to use when updating the field.
getURL(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getURL(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getURL() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getURL(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getURL(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getUseAliases() - Method in class org.apache.openjpa.jdbc.kernel.ClassTableJDBCSeq
Whether to use type alises for primary key values in place of class names.
getUseBuiltinIdentityClass() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Whether to use built in identity classes when possible.
getUseClassCriteria() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
getUseClassCriteria() - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
Whether to use class criteria when joining to related type.
getUseClassCriteria() - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
getUseClassCriteria() - Method in class org.apache.openjpa.jdbc.meta.ValueMappingInfo
Whether to use class criteria when joining to related type.
getUseDataStoreIdentity() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Whether to use datastore identity when possible.
getUseForeignKeyName() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Return whether the foreign key name will be used to generate relation names.
getUsePCRegistry() - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
Whether to attempt to use the information from registered classes to populate metadata defaults.
getUserName() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getUserObject(Object) - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
 
getUserObject(Object) - Method in interface org.apache.openjpa.kernel.Broker
Get the value for the specified key from the map of user objects.
getUserObject(Object) - Method in interface org.apache.openjpa.kernel.BrokerFactory
Get the value for the specified key from the map of user objects.
getUserObject(Object) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getUserObject(Object) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getUserObject(Object) - Method in class org.apache.openjpa.kernel.DelegatingBrokerFactory
 
getUserObject(Object) - Method in class org.apache.openjpa.persistence.EntityManagerFactoryImpl
 
getUserObject(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getUserObject(Object) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Get the value for the specified key from the map of user objects.
getUserObject(Object) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManagerFactory
Get the value for the specified key from the map of user objects.
getUseSchemaName() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Return true if the schema name will be included in the generated class name for each table.
getValidate() - Method in class org.apache.openjpa.meta.MetaDataRepository
The metadata validation level.
getValidateFalseReturnsHollow() - Method in class org.apache.openjpa.conf.Compatibility
Whether to return hollow instances to broker lookups with a validate parameter of false.
getValidateTrueChecksStore() - Method in class org.apache.openjpa.conf.Compatibility
Whether to check the datastore for the existence of a nontransactional cached object in broker lookups with a validate parameter of true.
getValidColumnName(String, Table) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Make any necessary changes to the given column name to make it valid for the current DB.
getValidForeignKeyName(String, Table, Table) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Make any necessary changes to the given foreign key name to make it valid for the current DB.
getValidIndexName(String, Table) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Make any necessary changes to the given index name to make it valid for the current DB.
getValidPrimaryKeyName(String, Table) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Make any necessary changes to the given primary key name to make it valid for the current DB.
getValidSequenceName(String, Schema) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Make any necessary changes to the given sequence name to make it valid for the current DB.
getValidTableName(String, Schema) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Make any necessary changes to the given table name to make it valid for the current DB.
getValidUniqueName(String, Table) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Make any necessary changes to the given unique constraint name to make it valid for the current DB.
getVals() - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
 
getValue() - Method in interface org.apache.openjpa.jdbc.kernel.exps.FilterValue
If this is a constant, return its value, else return null.
getValue() - Method in class org.apache.openjpa.jdbc.meta.Discriminator
The discriminator value.
getValue() - Method in class org.apache.openjpa.jdbc.meta.DiscriminatorMappingInfo
Raw discriminator value string.
getValue(Discriminator, boolean) - Method in class org.apache.openjpa.jdbc.meta.DiscriminatorMappingInfo
Return the discriminator value as an object of the right type.
getValue(Object[]) - Method in interface org.apache.openjpa.kernel.exps.Constant
Return the value for this constant given the specified parameters.
getValue() - Method in interface org.apache.openjpa.kernel.exps.Literal
The value of this literal.
getValue(String) - Method in interface org.apache.openjpa.lib.conf.Configuration
Return the Value for the given property, or null if none.
getValue(String) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
getValue() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap.Entry
 
getValue() - Method in class org.apache.openjpa.meta.FieldMetaData
MetaData about the field value.
getValueColumns(ClassMapping) - Method in interface org.apache.openjpa.jdbc.meta.strats.LRSMapFieldStrategy
Return the columns holding data for a map value for the given value mapping from LRSMapFieldStrategy.getIndependentKeyMappings(boolean) or LRSMapFieldStrategy.getIndependentValueMappings(boolean) (or null).
getValueColumns(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapInverseKeyFieldStrategy
 
getValueColumns(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapTableFieldStrategy
 
getValueIndex() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
getValueIndex() - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
Index on this value's columns, or null if none.
getValueIndex() - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
getValueInfo() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
getValueInfo() - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
Raw mapping data.
getValueInfo() - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
getValueMappedBy() - Method in class org.apache.openjpa.meta.FieldMetaData
 
getValueMappedBy() - Method in interface org.apache.openjpa.meta.ValueMetaData
The field that this value shares a mapping with.
getValueMappedBy() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
getValueMappedByMapping() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
getValueMappedByMapping() - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
Convenience method to perform cast from ValueMetaData.getValueMappedByMetaData().
getValueMappedByMapping() - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
getValueMappedByMetaData() - Method in class org.apache.openjpa.meta.FieldMetaData
 
getValueMappedByMetaData() - Method in interface org.apache.openjpa.meta.ValueMetaData
The field that this value shares a mapping with.
getValueMappedByMetaData() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
getValueMapping() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Convenience method to perform cast from FieldMetaData.getValue()
getValues() - Method in class org.apache.openjpa.ant.MetaDataToolTask.Action
 
getValues() - Method in class org.apache.openjpa.jdbc.ant.MappingToolTask.Action
 
getValues() - Method in class org.apache.openjpa.jdbc.ant.MappingToolTask.SchemaAction
 
getValues() - Method in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask.Level
 
getValues() - Method in class org.apache.openjpa.jdbc.ant.SchemaToolTask.Action
 
getValues() - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
 
getValues() - Method in interface org.apache.openjpa.kernel.exps.Arguments
Return the values that make up the arguments.
getValues() - Method in interface org.apache.openjpa.lib.conf.Configuration
Return the set of all Values.
getValues() - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
getValueSequence(FieldMetaData) - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
Returns null.
getValueSequence(FieldMetaData) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
getValueSequence(FieldMetaData) - Method in interface org.apache.openjpa.kernel.Broker
Returns a Seq for the generated values of the specified field, or null if the field is not generated.
getValueSequence(FieldMetaData) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getValueSequence(FieldMetaData) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getValueSequence(FieldMetaData) - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
getValueSequence(FieldMetaData) - Method in interface org.apache.openjpa.kernel.StoreManager
Return a sequence that generates values for the given field.
getValueSequenceMetaData() - Method in class org.apache.openjpa.meta.FieldMetaData
Metadata for the value sequence.
getValueSequenceName() - Method in class org.apache.openjpa.meta.FieldMetaData
The value sequence name, or null for none.
getValueStrategy() - Method in class org.apache.openjpa.meta.FieldMetaData
The strategy to use for insert value generation.
getValueType() - Method in class org.apache.openjpa.lib.conf.BooleanValue
 
getValueType() - Method in class org.apache.openjpa.lib.conf.DoubleValue
 
getValueType() - Method in class org.apache.openjpa.lib.conf.FileValue
 
getValueType() - Method in class org.apache.openjpa.lib.conf.IntValue
 
getValueType() - Method in class org.apache.openjpa.lib.conf.ObjectValue
 
getValueType() - Method in class org.apache.openjpa.lib.conf.PluginListValue
 
getValueType() - Method in class org.apache.openjpa.lib.conf.PluginValue
 
getValueType() - Method in class org.apache.openjpa.lib.conf.StringListValue
 
getValueType() - Method in class org.apache.openjpa.lib.conf.StringValue
 
getValueType() - Method in class org.apache.openjpa.lib.conf.Value
Returns the type of the property that this Value represents.
getValueUnique() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
getValueUnique() - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
Unique constraint on this value's columns, or null if none.
getValueUnique() - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
getVariable(String, boolean) - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
Returns a value for the given id.
getVersion() - Method in class org.apache.openjpa.datacache.DataCachePCDataImpl
 
getVersion() - Method in interface org.apache.openjpa.enhance.StateManager
Returns the optimistic version for this instance.
getVersion() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
The version indicator.
getVersion(Object) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
getVersion(Object) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
getVersion() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
getVersion() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
getVersion() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
getVersion() - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return the current version indicator for this instance.
getVersion() - Method in interface org.apache.openjpa.kernel.PCData
Returns the current version object that this data was loaded from.
getVersion() - Method in class org.apache.openjpa.kernel.PCDataImpl
 
getVersion() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
getVersion(Object) - Method in interface org.apache.openjpa.kernel.StoreContext
Returns the current version indicator for o.
getVersion(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
getVersion(Object) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Returns the current version indicator for o.
getVersion() - Method in class org.apache.openjpa.xmlstore.ObjectData
Get the version number of the object.
getVersionCheckOnReadLock() - Method in class org.apache.openjpa.kernel.VersionLockManager
Whether or not we should force a version check at commit time when a read lock is requested in order to verify read consistency.
getVersionColumnName() - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default base name for version identity columns, or null to the mapping's built-in name.
getVersionColumns(String, String, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
getVersionField() - Method in class org.apache.openjpa.meta.ClassMetaData
Return the version field for this class, if any.
getVersionFieldMapping() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Convenience method to perform cast from ClassMetaData.getVersionField().
getVersionSpecificClass(Class) - Static method in class org.apache.openjpa.lib.util.JavaVersions
Returns a version-specific instance of the specified class
getVersionSpecificClass(String) - Static method in class org.apache.openjpa.lib.util.JavaVersions
Obtains a subclass of the specific base class that is specific to the current version of Java in use.
getVersionStrategy() - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default version strategy alias.
getVersionStrategy() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Default version strategy for base class mappings.
getVersionUpdateOnWriteLock() - Method in class org.apache.openjpa.kernel.VersionLockManager
Whether or not we should force an update to the version at commit time when a write lock is requested.
getWaitingThreads(Condition) - Method in class org.apache.openjpa.lib.util.concurrent.ReentrantLock
Returns a collection containing those threads that may be waiting on the given condition associated with this lock.
getWaitingThreads() - Method in class org.apache.openjpa.lib.util.concurrent.WaitQueue
 
getWaitQueueLength(Condition) - Method in class org.apache.openjpa.lib.util.concurrent.ReentrantLock
Returns an estimate of the number of threads waiting on the given condition associated with this lock.
getWarningAction() - Method in class org.apache.openjpa.lib.jdbc.LoggingConnectionDecorator
What to do with SQL warnings.
getWarningHandler() - Method in class org.apache.openjpa.lib.jdbc.LoggingConnectionDecorator
What to do with SQL warnings.
getWarnings() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
getWarnings() - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
getWarnings() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
getWarnings() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
getWarnings() - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
getWhere(Select, boolean) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return the WHERE portion of the select statement, or null if no where conditions.
getWhere() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
getWhere(Column) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
Return the value set for where on the given column.
getWhere() - Method in interface org.apache.openjpa.jdbc.sql.Select
Return the WHERE clause, minus any necessary end joins.
getWhere() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
getWrapIndent() - Method in class org.apache.openjpa.lib.jdbc.SQLFormatter
 
getWrapper(int) - Method in class org.apache.openjpa.enhance.DynamicStorageGenerator
get the wrapper for the given JavaTypes constant.
getWrapper(Class) - Method in class org.apache.openjpa.enhance.DynamicStorageGenerator
Get the wrapper for the given type.
getWriteLockLevel() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The default write lock level to use during non-optimistic transactions.
getWriteLockLevel() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getWriteLockLevel() - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
getWriteLockLevel() - Method in interface org.apache.openjpa.kernel.FetchConfiguration
The lock level to use for locking dirtied objects.
getWriteLockLevel() - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
getWriteLockLevelConstant() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The numeric write lock level.
getWriteLockLevelConstant() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
getWriteLockMode() - Method in interface org.apache.openjpa.persistence.FetchPlan
The lock level to use for locking dirtied objects.
getWriteLockMode() - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
getWriter() - Method in class org.apache.openjpa.enhance.ApplicationIdTool
The writer to write source to, or null to write to default file.
getWriter() - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
The stream to write to for the creation of SQL scripts.
getWriter(String, ClassLoader) - Static method in class org.apache.openjpa.lib.util.Files
Return a writer to the stream(stdout or stderr) or file named by the given string.
getWriter() - Method in class org.apache.openjpa.meta.MetaDataTool
The writer to generate metadata to.
getXMLParser() - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
Return XML metadata parser, creating it if it does not already exist.
greaterThan(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
greaterThan(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return an expression representing the given condition.
greaterThan(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
greaterThanEqual(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
greaterThanEqual(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return an expression representing the given condition.
greaterThanEqual(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
group(QueryExpressions, List, StoreContext, Object[]) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
Group the list of matches into a list of lists.
GROUP_ALL - Static variable in interface org.apache.openjpa.persistence.FetchPlan
Fetch group representing all fields.
GROUP_DEFAULT - Static variable in interface org.apache.openjpa.persistence.FetchPlan
The default fetch group.
groupBy(Select, ExpContext, ExpState) - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
 
groupBy(Select, ExpContext, ExpState) - Method in interface org.apache.openjpa.jdbc.kernel.exps.Val
Group by this value.
groupBy(SQLBuffer) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
groupBy(SQLBuffer, Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
groupBy(String) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
groupBy(String, Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
groupBy(Column) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
groupBy(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
groupBy(Column[]) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
groupBy(Column[], Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
groupBy(ClassMapping, int, JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
groupBy(ClassMapping, int, JDBCStore, JDBCFetchConfiguration, Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
groupBy(Column) - Method in interface org.apache.openjpa.jdbc.sql.Select
Group by the given column.
groupBy(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
Group by the given column.
groupBy(Column[]) - Method in interface org.apache.openjpa.jdbc.sql.Select
Group by the given columns.
groupBy(Column[], Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
Group by the given columns.
groupBy(SQLBuffer) - Method in interface org.apache.openjpa.jdbc.sql.Select
Add a GROUP BY clause.
groupBy(SQLBuffer, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
Add a GROUP BY clause.
groupBy(String) - Method in interface org.apache.openjpa.jdbc.sql.Select
Add a GROUP BY clause.
groupBy(String, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
Add a GROUP BY clause.
groupBy(ClassMapping, int, JDBCStore, JDBCFetchConfiguration) - Method in interface org.apache.openjpa.jdbc.sql.Select
Group by the columns of the given mapping, possibly including subclasses.
groupBy(ClassMapping, int, JDBCStore, JDBCFetchConfiguration, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
Group by the columns of the given mapping, possibly including subclasses.
groupBy(SQLBuffer) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
groupBy(SQLBuffer, Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
groupBy(String) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
groupBy(String, Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
groupBy(Column) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
groupBy(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
groupBy(Column[]) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
groupBy(Column[], Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
groupBy(ClassMapping, int, JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
groupBy(ClassMapping, int, JDBCStore, JDBCFetchConfiguration, Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
groupByPackage(Collection) - Method in class org.apache.openjpa.lib.meta.CFMetaDataSerializer
Helper method to group objects by package.
grouping - Variable in class org.apache.openjpa.jdbc.kernel.exps.QueryExpressionsState
 
grouping - Variable in class org.apache.openjpa.kernel.exps.QueryExpressions
 
groupingClauses - Variable in class org.apache.openjpa.kernel.exps.QueryExpressions
 

H

haltOnError - Variable in class org.apache.openjpa.lib.ant.AbstractTask
 
handleCheckedException(Exception) - Method in class org.apache.openjpa.jdbc.kernel.GenericResultObjectProvider
 
handleCheckedException(Exception) - Method in class org.apache.openjpa.jdbc.kernel.SelectResultObjectProvider
 
handleCheckedException(Exception) - Method in class org.apache.openjpa.kernel.AbstractPCResultObjectProvider
Throws a StoreException by default.
handleCheckedException(Exception) - Method in class org.apache.openjpa.lib.rop.ListResultObjectProvider
 
handleCheckedException(Exception) - Method in class org.apache.openjpa.lib.rop.MergedResultObjectProvider
 
handleCheckedException(Exception) - Method in class org.apache.openjpa.lib.rop.RangeResultObjectProvider
 
handleCheckedException(Exception) - Method in interface org.apache.openjpa.lib.rop.ResultObjectProvider
Any checked exceptions that are thrown will be passed to this method.
handlerCollectionStrategy(FieldMapping, ValueHandler, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Return the collection strategy for the given element handler, or null if none.
HandlerFieldStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Mapping for a single-valued field that delegates to a ValueHandler.
HandlerFieldStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
handlerMapStrategy(FieldMapping, ValueHandler, ValueHandler, boolean, boolean, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Return the map strategy for the given key and value handlers / relations, or null if none.
HandlerStrategies - Class in org.apache.openjpa.jdbc.meta.strats
Utility methods for strategies using value handlers.
HandlerStrategies() - Constructor for class org.apache.openjpa.jdbc.meta.strats.HandlerStrategies
 
handleUnknownClassAnnotation(ClassMetaData, Annotation) - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Allow subclasses to handle unknown annotations.
handleUnknownClassMappingAnnotation(ClassMapping, Annotation) - Method in class org.apache.openjpa.persistence.jdbc.AnnotationPersistenceMappingParser
Allow subclasses to handle unknown annotations.
handleUnknownMemberAnnotation(FieldMetaData, Annotation) - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Allow subclasses to handle unknown annotations.
handleUnknownMemberMappingAnnotation(FieldMapping, Annotation) - Method in class org.apache.openjpa.persistence.jdbc.AnnotationPersistenceMappingParser
Allow subclasses to handle unknown annotations.
handleUnknownPackageAnnotation(Package, Annotation) - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Allow subclasses to handle unknown annotations.
handleUnknownPackageMappingAnnotation(Package, Annotation) - Method in class org.apache.openjpa.persistence.jdbc.AnnotationPersistenceMappingParser
Allow subclasses to handle unknown annotations.
handleWarning(SQLWarning) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Implementation of the LoggingConnectionDecorator.SQLWarningHandler interface that allows customization of the actions to perform when a SQLWarning occurs at any point on a Connection, Statement, or ResultSet.
handleWarning(SQLWarning) - Method in interface org.apache.openjpa.lib.jdbc.LoggingConnectionDecorator.SQLWarningHandler
 
HARD - Static variable in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashSet
Hard reference marker.
HARD - Static variable in class org.apache.openjpa.lib.util.ReferenceHashSet
Hard reference marker.
HARD - Static variable in interface org.apache.openjpa.lib.util.ReferenceMap
 
has(Object) - Method in class org.apache.openjpa.jdbc.meta.strats.LRSProxyCollection
 
has(Object) - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
Return whether the collection contains the given element.
hasAttachListeners(Object, ClassMetaData) - Method in class org.apache.openjpa.event.LifecycleEventManager
Return whether there are listeners or callbacks for the given source.
hasAutoAssignConstraints() - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy.CustomUpdate
 
hasAutoAssignConstraints() - Method in class org.apache.openjpa.jdbc.sql.RowManagerImpl
Whether any primary rows have auto-assign constraints.
hasBeginListeners() - Method in class org.apache.openjpa.event.TransactionEventManager
Whether there are any begin transaction listeners.
hasCallback(Object, int) - Method in interface org.apache.openjpa.event.LifecycleCallbacks
Return whether the given instance has a callback for the given event type.
hasCallback(Object, int) - Method in class org.apache.openjpa.event.MethodLifecycleCallbacks
 
hasClearListeners(Object, ClassMetaData) - Method in class org.apache.openjpa.event.LifecycleEventManager
Return whether there are listeners or callbacks for the given source.
hasConnection() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
hasConnection() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
hasConnection() - Method in interface org.apache.openjpa.kernel.StoreContext
Whether the broker has a dedicated connection based on the configured connection retain mode and transaction status.
hasDeleteListeners(Object, ClassMetaData) - Method in class org.apache.openjpa.event.LifecycleEventManager
Return whether there are listeners or callbacks for the given source.
hasDetachListeners(Object, ClassMetaData) - Method in class org.apache.openjpa.event.LifecycleEventManager
Return whether there are listeners or callbacks for the given source.
hasDirtyListeners(Object, ClassMetaData) - Method in class org.apache.openjpa.event.LifecycleEventManager
Return whether there are listeners or callbacks for the given source.
hasEager(List, FieldMapping) - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping.PCResult
Return true if the mapped result contains eager data for the given field at the given path.
hasEagerJoin(boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
hasEagerJoin(boolean) - Method in interface org.apache.openjpa.jdbc.sql.Select
Whether this select has an eager join of the specified type.
hasEagerJoin(boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
hasEndListeners() - Method in class org.apache.openjpa.event.TransactionEventManager
Whether there are any end transaction listeners.
hasExtension(String) - Method in class org.apache.openjpa.meta.Extensions
Return true if the extension with the given key exists.
hasExtension(String, String) - Method in class org.apache.openjpa.meta.Extensions
Return true if the extension with the given key exists.
hasFetchGroup(String) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
hasFetchGroup(String) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Return true if the given fetch group has been added.
hasFetchGroup(String) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
hasField(String) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
hasField(String) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Return true if the given fully-qualified field has been added.
hasField(String) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
hasField(String) - Method in interface org.apache.openjpa.persistence.FetchPlan
Return true if the given field has been added.
hasField(Class, String) - Method in interface org.apache.openjpa.persistence.FetchPlan
Return true if the given field has been added.
hasField(String) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
hasField(Class, String) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
hasFlushListeners() - Method in class org.apache.openjpa.event.TransactionEventManager
Whether there are any flush transaction listeners.
hasGrouping(StoreQuery) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery.AbstractExecutor
 
hasGrouping() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
hasGrouping() - Method in interface org.apache.openjpa.kernel.QueryContext
Return true if the query uses grouping.
hasGrouping() - Method in class org.apache.openjpa.kernel.QueryImpl
 
hasGrouping(StoreQuery) - Method in interface org.apache.openjpa.kernel.StoreQuery.Executor
Whether the compiled query has grouping.
hashCode() - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
hashCode() - Method in class org.apache.openjpa.datacache.DelegatingQueryCache
 
hashCode() - Method in class org.apache.openjpa.datacache.QueryKey
Define a hashing algorithm corresponding to the QueryKey.equals(java.lang.Object) method defined above.
hashCode() - Method in class org.apache.openjpa.jdbc.sql.Join
 
hashCode() - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
 
hashCode() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
hashCode() - Method in class org.apache.openjpa.kernel.DelegatingBrokerFactory
 
hashCode() - Method in class org.apache.openjpa.kernel.DelegatingExtent
 
hashCode() - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
hashCode() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
hashCode() - Method in class org.apache.openjpa.kernel.DelegatingResultList.DelegatingListIterator
 
hashCode() - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
hashCode() - Method in class org.apache.openjpa.kernel.DelegatingSeq
 
hashCode() - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
hashCode() - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
hashCode() - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
Computes hash code based on the properties returned from ConfigurationImpl.toProperties(boolean).
hashCode() - Method in class org.apache.openjpa.lib.conf.Value
 
hashCode() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
hashCode() - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
hashCode() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
hashCode() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDataSource
 
hashCode() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
hashCode() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
hashCode() - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
hashCode() - Method in class org.apache.openjpa.lib.rop.LazyForwardResultList
 
hashCode() - Method in class org.apache.openjpa.lib.rop.RandomAccessResultList
 
hashCode() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap.Entry
 
hashCode() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashSet
 
hashCode() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashSet
 
hashCode() - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
hashCode() - Method in class org.apache.openjpa.lib.util.MultiClassLoader
 
hashCode() - Method in class org.apache.openjpa.lib.util.ReferenceHashSet
 
hashCode() - Method in class org.apache.openjpa.meta.ClassMetaData
 
hashCode() - Method in class org.apache.openjpa.meta.FetchGroup
 
hashCode() - Method in class org.apache.openjpa.meta.FieldMetaData
 
hashCode() - Method in class org.apache.openjpa.persistence.EntityManagerFactoryImpl
 
hashCode() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
hashCode() - Method in class org.apache.openjpa.persistence.ExtentImpl
 
hashCode() - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
hashCode() - Method in class org.apache.openjpa.persistence.GeneratorImpl
 
hashCode() - Method in class org.apache.openjpa.persistence.QueryImpl
 
hashCode() - Method in class org.apache.openjpa.persistence.QueryResultCacheImpl
 
hashCode() - Method in class org.apache.openjpa.persistence.StoreCacheImpl
 
hashCode() - Method in class org.apache.openjpa.util.OpenJPAId
 
hasJoin(String) - Method in class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
 
hasJoin(String) - Method in interface org.apache.openjpa.jdbc.kernel.JDBCFetchConfiguration
Return true if the given fully-qualified join has been added.
hasJoin(String) - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
hasJoin(boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
hasJoin(boolean) - Method in interface org.apache.openjpa.jdbc.sql.Select
Whether this select has a join of the specified type.
hasJoin(boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
hasKey(Object) - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
Return whether the given key exists in the map.
hasListener(Object) - Method in class org.apache.openjpa.lib.util.AbstractEventManager
Return whether the given instance is in the list of listeners.
hasListener(Object) - Method in class org.apache.openjpa.lib.util.concurrent.AbstractConcurrentEventManager
Return whether the given instance is in the list of listeners.
hasListener(Object) - Method in interface org.apache.openjpa.lib.util.EventManager
Return whether the given instance is in the list of listeners.
hasListeners(int) - Method in class org.apache.openjpa.event.LifecycleEventManager.ListenerList
 
hasListeners() - Method in class org.apache.openjpa.lib.util.AbstractEventManager
Return true if there are any registered listeners.
hasListeners() - Method in class org.apache.openjpa.lib.util.concurrent.AbstractConcurrentEventManager
Return true if there are any registered listeners.
hasListeners() - Method in interface org.apache.openjpa.lib.util.EventManager
Return true if there are any registered listeners.
hasLoadListeners(Object, ClassMetaData) - Method in class org.apache.openjpa.event.LifecycleEventManager
Return whether there are listeners or callbacks for the given source.
hasNext() - Method in class org.apache.openjpa.kernel.DelegatingResultList.DelegatingListIterator
 
hasNext() - Method in class org.apache.openjpa.lib.meta.ClassMetaDataIterator
 
hasNext() - Method in class org.apache.openjpa.lib.meta.FileMetaDataIterator
 
hasNext() - Method in interface org.apache.openjpa.lib.meta.MetaDataIterator
Return whether there is another resource to iterate over.
hasNext() - Method in class org.apache.openjpa.lib.meta.MetaDataIteratorChain
 
hasNext() - Method in class org.apache.openjpa.lib.meta.ResourceMetaDataIterator
 
hasNext() - Method in class org.apache.openjpa.lib.meta.URLMetaDataIterator
 
hasNext() - Method in class org.apache.openjpa.lib.meta.ZipFileMetaDataIterator
 
hasNext() - Method in class org.apache.openjpa.lib.meta.ZipStreamMetaDataIterator
 
hasNext() - Method in class org.apache.openjpa.lib.rop.ResultListIterator
 
hasNext() - Method in class org.apache.openjpa.lib.rop.ResultObjectProviderIterator
 
hasNodes() - Method in class org.apache.openjpa.lib.util.concurrent.WaitQueue
 
hasParameter(String) - Method in class org.apache.openjpa.lib.util.ParameterTemplate
Return true if the given parameter has been given a value.
hasPersistListeners(Object, ClassMetaData) - Method in class org.apache.openjpa.event.LifecycleEventManager
Return whether there are listeners or callbacks for the given source.
hasPositionalParameters() - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Whether this query has positional parameters.
hasPositionalParameters() - Method in class org.apache.openjpa.persistence.QueryImpl
 
hasPrevious() - Method in class org.apache.openjpa.kernel.DelegatingResultList.DelegatingListIterator
 
hasPrevious() - Method in class org.apache.openjpa.lib.rop.ResultListIterator
 
hasQueuedThread(Thread) - Method in class org.apache.openjpa.lib.util.concurrent.ReentrantLock
Queries whether the given thread is waiting to acquire this lock.
hasQueuedThreads() - Method in class org.apache.openjpa.lib.util.concurrent.ReentrantLock
Queries whether any threads are waiting to acquire this lock.
hasSchemaComponents() - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
 
hasSchemaComponents() - Method in class org.apache.openjpa.jdbc.meta.FieldMappingInfo
 
hasSchemaComponents() - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Return true if this info has columns, foreign key information, index information, etc.
hasStoreListeners(Object, ClassMetaData) - Method in class org.apache.openjpa.event.LifecycleEventManager
Return whether there are listeners or callbacks for the given source.
hasSubclasses() - Method in class org.apache.openjpa.kernel.DelegatingExtent
 
hasSubclasses() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
hasSubclasses() - Method in interface org.apache.openjpa.kernel.Extent
Whether the extent includes subclasses.
hasSubclasses() - Method in class org.apache.openjpa.kernel.ExtentImpl
 
hasSubclasses() - Method in interface org.apache.openjpa.kernel.QueryContext
Whether query results will include subclasses of the candidate class.
hasSubclasses() - Method in class org.apache.openjpa.kernel.QueryImpl
 
hasSubclasses() - Method in interface org.apache.openjpa.persistence.Extent
Whether the extent includes subclasses.
hasSubclasses() - Method in class org.apache.openjpa.persistence.ExtentImpl
 
hasSubclasses() - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Whether subclasses are included in the query results.
hasSubclasses() - Method in class org.apache.openjpa.persistence.QueryImpl
 
hasSubclasses() - Method in class org.apache.openjpa.util.OpenJPAId
Whether this oid might be for a subclass of the given type.
hasValue(Object) - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
Return whether the given value exists in the map.
hasWaiters(Condition) - Method in class org.apache.openjpa.lib.util.concurrent.ReentrantLock
Queries whether any threads are waiting on the given condition associated with this lock.
having - Variable in class org.apache.openjpa.jdbc.kernel.exps.QueryExpressionsState
 
having(SQLBuffer) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
having(SQLBuffer, Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
having(String) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
having(String, Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
having(SQLBuffer) - Method in interface org.apache.openjpa.jdbc.sql.Select
Add the given having conditions.
having(SQLBuffer, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
Add the given having conditions.
having(String) - Method in interface org.apache.openjpa.jdbc.sql.Select
Add the given having conditions.
having(String, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
Add the given having conditions.
having(SQLBuffer) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
having(SQLBuffer, Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
having(String) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
having(String, Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
having - Variable in class org.apache.openjpa.kernel.exps.QueryExpressions
 
hints - Variable in class org.apache.openjpa.kernel.FetchConfigurationImpl.ConfigurationState
 
hintToAggregateListener(Object, ClassLoader) - Static method in class org.apache.openjpa.kernel.Filters
Convert the user-given hint value to an aggregate listener.
hintToAggregateListeners(Object, ClassLoader) - Static method in class org.apache.openjpa.kernel.Filters
Convert the user-given hint value to an array of aggregate listeners.
hintToFilterListener(Object, ClassLoader) - Static method in class org.apache.openjpa.kernel.Filters
Convert the user-given hint value to a filter listener.
hintToFilterListeners(Object, ClassLoader) - Static method in class org.apache.openjpa.kernel.Filters
Convert the user-given hint value to an array of filter listeners.
hintToGetter(Object, String) - Static method in class org.apache.openjpa.kernel.Filters
Return the value of the property named by the hint key.
hintToSetter(Object, String, Object) - Static method in class org.apache.openjpa.kernel.Filters
Set the value of the property named by the hint key.
HOLLOW - Static variable in class org.apache.openjpa.kernel.PCState
Hollow; exists in data store
HOURS - Static variable in class org.apache.openjpa.lib.util.concurrent.TimeUnit
 
HSQLDictionary - Class in org.apache.openjpa.jdbc.sql
Dictionary for Hypersonic SQL database.
HSQLDictionary() - Constructor for class org.apache.openjpa.jdbc.sql.HSQLDictionary
 

I

Id - Class in org.apache.openjpa.util
Datastore identity type.
Id(String) - Constructor for class org.apache.openjpa.util.Id
Create an id from the result of a OpenJPAId.toString() call on another instance.
Id(String, OpenJPAConfiguration, ClassLoader) - Constructor for class org.apache.openjpa.util.Id
Create an id from the result of an OpenJPAId.toString() call on another instance.
Id(String, ClassLoader) - Constructor for class org.apache.openjpa.util.Id
Create an id from the result of an OpenJPAId.toString() call on another instance.
Id(Class, String) - Constructor for class org.apache.openjpa.util.Id
Construct from the result of a OpenJPAId.toString() call on another instance.
Id(Class, Long) - Constructor for class org.apache.openjpa.util.Id
Construct from key value.
Id(Class, long) - Constructor for class org.apache.openjpa.util.Id
Construct from key value.
Id(Class, long, boolean) - Constructor for class org.apache.openjpa.util.Id
Construct from key value.
ID_APPLICATION - Static variable in class org.apache.openjpa.meta.ClassMetaData
Application identity type.
ID_DATASTORE - Static variable in class org.apache.openjpa.meta.ClassMetaData
Datastore identity type.
ID_UNKNOWN - Static variable in class org.apache.openjpa.meta.ClassMetaData
Unkonwn identity type.
identityClassSuffix - Variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool.Flags
 
identityColumnName - Variable in class org.apache.openjpa.jdbc.sql.SybaseDictionary
If SybaseDictionary.createIdentityColumn is true, then the identityColumnName will be the name of the additional unique column that will be created.
idEquals(OpenJPAId) - Method in class org.apache.openjpa.util.ByteId
 
idEquals(OpenJPAId) - Method in class org.apache.openjpa.util.CharId
 
idEquals(OpenJPAId) - Method in class org.apache.openjpa.util.DateId
 
idEquals(OpenJPAId) - Method in class org.apache.openjpa.util.Id
 
idEquals(OpenJPAId) - Method in class org.apache.openjpa.util.IntId
 
idEquals(OpenJPAId) - Method in class org.apache.openjpa.util.LongId
 
idEquals(OpenJPAId) - Method in class org.apache.openjpa.util.ObjectId
 
idEquals(OpenJPAId) - Method in class org.apache.openjpa.util.OpenJPAId
Compare the id to the id of the given instance.
idEquals(OpenJPAId) - Method in class org.apache.openjpa.util.ShortId
 
idEquals(OpenJPAId) - Method in class org.apache.openjpa.util.StringId
 
idHash() - Method in class org.apache.openjpa.util.ByteId
 
idHash() - Method in class org.apache.openjpa.util.CharId
 
idHash() - Method in class org.apache.openjpa.util.DateId
 
idHash() - Method in class org.apache.openjpa.util.Id
 
idHash() - Method in class org.apache.openjpa.util.IntId
 
idHash() - Method in class org.apache.openjpa.util.LongId
 
idHash() - Method in class org.apache.openjpa.util.ObjectId
 
idHash() - Method in class org.apache.openjpa.util.OpenJPAId
Return the id's hash code.
idHash() - Method in class org.apache.openjpa.util.ShortId
 
idHash() - Method in class org.apache.openjpa.util.StringId
 
IGNORE - Static variable in class org.apache.openjpa.meta.UpdateStrategies
Ignore updates; field is always considered clean.
IGNORE_HIGH - Static variable in class org.apache.openjpa.meta.LifecycleMetaData
 
IGNORE_LOW - Static variable in class org.apache.openjpa.meta.LifecycleMetaData
 
IGNORE_NONE - Static variable in class org.apache.openjpa.meta.LifecycleMetaData
 
ignoreChanges - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
ignoreContent(boolean) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Ignore all content below the current element.
ignoreErrors - Variable in class org.apache.openjpa.enhance.ApplicationIdTool.Flags
 
ignoreErrors - Variable in class org.apache.openjpa.jdbc.meta.MappingTool.Flags
 
ignoreErrors - Variable in class org.apache.openjpa.jdbc.schema.SchemaTool.Flags
 
ignoreLoaded(FieldMetaData) - Static method in class org.apache.openjpa.kernel.DetachedStateManager
Ignore if the field is not dirty but loaded
ImmutableValueHandler - Class in org.apache.openjpa.jdbc.meta.strats
Handler for simple type and string values.
ImmutableValueHandler() - Constructor for class org.apache.openjpa.jdbc.meta.strats.ImmutableValueHandler
 
IMPL_CLASS_TABLE - Static variable in class org.apache.openjpa.jdbc.meta.SequenceMapping
ClassTableJDBCSeq alias.
IMPL_NATIVE - Static variable in class org.apache.openjpa.meta.SequenceMetaData
Default plugin alias name; every back end should have some 'native' sequence implementation.
IMPL_TABLE - Static variable in class org.apache.openjpa.jdbc.meta.SequenceMapping
TableJDBCSeq alias.
IMPL_TIME - Static variable in class org.apache.openjpa.meta.SequenceMetaData
Time-based sequence values.
IMPL_VALUE_TABLE - Static variable in class org.apache.openjpa.jdbc.meta.SequenceMapping
ValueTableJDBCSeq alias.
implementsDec(int) - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
ImplHelper - Class in org.apache.openjpa.util
Helper for OpenJPA back-ends.
ImplHelper() - Constructor for class org.apache.openjpa.util.ImplHelper
 
importColumn(Column) - Method in class org.apache.openjpa.jdbc.schema.Table
Import a column from another table.
importForeignKey(ForeignKey) - Method in class org.apache.openjpa.jdbc.schema.Table
Import a foreign key; column names must match columns of this table.
importIndex(Index) - Method in class org.apache.openjpa.jdbc.schema.Table
Import an index; column names must match columns of this table.
importMappings(JDBCConfiguration, Class[], String[], boolean, Log, ClassLoader) - Method in interface org.apache.openjpa.jdbc.meta.MappingTool.ImportExport
Import mappings for the given classes based on the given arguments.
importPrimaryKey(PrimaryKey) - Method in class org.apache.openjpa.jdbc.schema.Table
Import a primary key; column names must match columns of this table.
importSchema(Schema) - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Import a schema from another group.
importSequence(Sequence) - Method in class org.apache.openjpa.jdbc.schema.Schema
Import a sequence from another schema.
importTable(Table) - Method in class org.apache.openjpa.jdbc.schema.Schema
Import a table from another schema.
importUnique(Unique) - Method in class org.apache.openjpa.jdbc.schema.Table
Import a constraint; column names must match columns of this table.
includes(String, boolean) - Method in class org.apache.openjpa.meta.FetchGroup
Affirms if given fetch group is included by this receiver.
INCREMENT - Static variable in class org.apache.openjpa.meta.ValueStrategies
"increment" value strategy.
Index - Class in org.apache.openjpa.jdbc.schema
Represents a database index.
Index() - Constructor for class org.apache.openjpa.jdbc.schema.Index
Default constructor.
Index(String, Table) - Constructor for class org.apache.openjpa.jdbc.schema.Index
Constructor.
Index - Annotation Type in org.apache.openjpa.persistence.jdbc
Index definition.
indexes - Variable in class org.apache.openjpa.jdbc.meta.MappingTool.Flags
 
indexes - Variable in class org.apache.openjpa.jdbc.schema.SchemaTool.Flags
 
indexOf(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
indexOf(SQLBuffer, FilterValue, FilterValue, FilterValue) - Method in class org.apache.openjpa.jdbc.sql.AbstractDB2Dictionary
 
indexOf() - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
indexOf(SQLBuffer, FilterValue, FilterValue, FilterValue) - Method in class org.apache.openjpa.jdbc.sql.AbstractSQLServerDictionary
 
indexOf(SQLBuffer, FilterValue, FilterValue, FilterValue) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Invoke this database's indexOf function.
indexOf(SQLBuffer, FilterValue, FilterValue, FilterValue) - Method in class org.apache.openjpa.jdbc.sql.HSQLDictionary
 
indexOf(SQLBuffer, FilterValue, FilterValue, FilterValue) - Method in class org.apache.openjpa.jdbc.sql.InterbaseDictionary
 
indexOf(SQLBuffer, FilterValue, FilterValue, FilterValue) - Method in class org.apache.openjpa.jdbc.sql.JDataStoreDictionary
 
indexOf() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
indexOf() - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
indexOf(SQLBuffer, FilterValue, FilterValue, FilterValue) - Method in class org.apache.openjpa.jdbc.sql.PointbaseDictionary
 
indexOf(SQLBuffer, FilterValue, FilterValue, FilterValue) - Method in class org.apache.openjpa.jdbc.sql.PostgresDictionary
 
indexOf() - Method in interface org.apache.openjpa.jdbc.sql.Result
The index of the select within the UNION that the current row corresponds to, or 0.
indexOf() - Method in interface org.apache.openjpa.jdbc.sql.Select
The index of this select within the UNION, or 0.
indexOf() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
indexOf(Object) - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
indexOf(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return a value representing the String.indexOf(int) function on the given target with the given args.
indexOf(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
indexOf(Object) - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
indexOf(Object) - Method in class org.apache.openjpa.lib.rop.AbstractNonSequentialResultList
 
indexOf(Object) - Method in class org.apache.openjpa.lib.rop.AbstractSequentialResultList
 
indexOf(Object) - Method in class org.apache.openjpa.lib.rop.ListResultList
 
indexOf(Object) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
indexOf(Object, int) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
indicatesNull(Object) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbeddedClassStrategy
Return whether the given null indicator value means the object is null.
info(Object) - Method in class org.apache.openjpa.lib.log.AbstractLog
 
info(Object, Throwable) - Method in class org.apache.openjpa.lib.log.AbstractLog
 
info(Object) - Method in class org.apache.openjpa.lib.log.CommonsLogFactory.LogAdapter
 
info(Object, Throwable) - Method in class org.apache.openjpa.lib.log.CommonsLogFactory.LogAdapter
 
INFO - Static variable in interface org.apache.openjpa.lib.log.Log
 
info(Object) - Method in interface org.apache.openjpa.lib.log.Log
Write out a log message at the Log.INFO level with the stringification of o as the body of the message, also outputting t to the log.
info(Object, Throwable) - Method in interface org.apache.openjpa.lib.log.Log
Write out a log message at the Log.INFO level with the stringification of o as the body of the message, also outputting t to the log.
info(Object) - Method in class org.apache.openjpa.lib.log.Log4JLogFactory.LogAdapter
 
info(Object, Throwable) - Method in class org.apache.openjpa.lib.log.Log4JLogFactory.LogAdapter
 
info(Object) - Method in class org.apache.openjpa.lib.log.NoneLogFactory.NoneLog
 
info(Object, Throwable) - Method in class org.apache.openjpa.lib.log.NoneLogFactory.NoneLog
 
INFO_STR - Static variable in class org.apache.openjpa.lib.log.LogFactoryImpl
 
InformixDictionary - Class in org.apache.openjpa.jdbc.sql
Dictionary for Informix database.
InformixDictionary() - Constructor for class org.apache.openjpa.jdbc.sql.InformixDictionary
 
InheritanceComparator - Class in org.apache.openjpa.meta
Comparator that keeps classes in inheritance order.
InheritanceComparator() - Constructor for class org.apache.openjpa.meta.InheritanceComparator
 
initCause(Throwable, Throwable) - Static method in class org.apache.openjpa.lib.util.JavaVersions
Set the cause of the given throwable.
initDBDictionary(DBDictionary) - Method in interface org.apache.openjpa.jdbc.schema.DriverDataSource
Initialize self and dictionary once available.
initDBDictionary(DBDictionary) - Method in class org.apache.openjpa.jdbc.schema.SimpleDriverDataSource
 
initializationMillis - Variable in class org.apache.openjpa.lib.log.LogFactoryImpl
The time at which this factory was initialized.
initializationSQL - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
initialize(OpenJPAStateManager, PCState, FetchConfiguration, Object) - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
This method is invoked when OpenJPA needs to load an object whose identity is known but which has not yet been loaded from the data store.
initialize(DataCacheManager) - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
initialize(DataCacheManager) - Method in class org.apache.openjpa.datacache.AbstractQueryCache
 
initialize(DataCacheManager) - Method in class org.apache.openjpa.datacache.ConcurrentDataCache
 
initialize(DataCacheManager) - Method in class org.apache.openjpa.datacache.ConcurrentQueryCache
 
initialize(DataCacheManager) - Method in interface org.apache.openjpa.datacache.DataCache
Initialize any resources associated with the given DataCacheManager.
initialize(OpenJPAConfiguration, ObjectValue, ObjectValue) - Method in interface org.apache.openjpa.datacache.DataCacheManager
Initialize the manager, supplying the cache configuration.
initialize(OpenJPAConfiguration, ObjectValue, ObjectValue) - Method in class org.apache.openjpa.datacache.DataCacheManagerImpl
 
initialize(OpenJPAStateManager, PCState, FetchConfiguration, Object) - Method in class org.apache.openjpa.datacache.DataCacheStoreManager
 
initialize(DataCacheManager) - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
initialize(DataCacheManager) - Method in class org.apache.openjpa.datacache.DelegatingQueryCache
 
initialize(DataCacheManager) - Method in interface org.apache.openjpa.datacache.QueryCache
Initialize any resources associated with the given DataCacheManager.
initialize() - Method in interface org.apache.openjpa.enhance.DynamicStorage
Ensure object capacity
initialize(Select, ExpContext, int) - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
 
initialize(Select, ExpContext, int) - Method in interface org.apache.openjpa.jdbc.kernel.exps.Val
Initialize the value.
initialize(OpenJPAStateManager, PCState, FetchConfiguration, Object) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
initialize() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
initialize() - Method in class org.apache.openjpa.jdbc.meta.Discriminator
 
initialize() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
initialize() - Method in interface org.apache.openjpa.jdbc.meta.Strategy
Perform caching and other initialization operations.
initialize() - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractStrategy
 
initialize() - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedFieldStrategy
 
initialize() - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
initialize() - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedBlobFieldStrategy
 
initialize() - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedByteArrayFieldStrategy
 
initialize() - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedCharArrayFieldStrategy
 
initialize() - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedClobFieldStrategy
 
initialize() - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
initialize() - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
initialize() - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyInverseKeyFieldStrategy
 
initialize() - Method in class org.apache.openjpa.jdbc.meta.strats.VerticalClassStrategy
 
initialize() - Method in class org.apache.openjpa.jdbc.meta.Version
 
initialize(OpenJPAStateManager, PCState, FetchConfiguration) - Method in class org.apache.openjpa.kernel.AbstractPCResultObjectProvider
 
initialize(AbstractBrokerFactory, DelegatingStoreManager, boolean, int) - Method in class org.apache.openjpa.kernel.BrokerImpl
Initialize the persistence manager.
initialize(StateManagerImpl, boolean, FetchConfiguration, Object) - Method in class org.apache.openjpa.kernel.BrokerImpl
Initialize a newly-constructed state manager.
initialize(OpenJPAStateManager, PCState, FetchConfiguration, Object) - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
initialize(Class, PCState) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
initialize(Class, PCState) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
initialize(Class, PCState) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
initialize(Class, PCState) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Initialize the state manager with a new instance of the given persistence capable type and the proper lifecycle state.
initialize(OpenJPAStateManager, PCState, FetchConfiguration) - Method in interface org.apache.openjpa.kernel.PCResultObjectProvider
Initializes the state manager.
initialize(Class, PCState) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
initialize(PersistenceCapable, PCState) - Method in class org.apache.openjpa.kernel.StateManagerImpl
Initialize with the given instance and state.
initialize(OpenJPAStateManager, PCState, FetchConfiguration, Object) - Method in interface org.apache.openjpa.kernel.StoreManager
Initialize the given state manager.
initialize(OpenJPAStateManager, PCState, FetchConfiguration, Object) - Method in class org.apache.openjpa.xmlstore.XMLStoreManager
 
initializeMapping() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
initializeMapping() - Method in class org.apache.openjpa.meta.ClassMetaData
Initialize mapping.
initialSequence() - Method in class org.apache.openjpa.util.AbstractChangeTracker
Return the initial sequence value for this proxy.
initialSequence() - Method in class org.apache.openjpa.util.CollectionChangeTrackerImpl
 
InMemoryExpressionFactory - Class in org.apache.openjpa.kernel.exps
Expression factory implementation that can be used to execute queries in memory.
InMemoryExpressionFactory() - Constructor for class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
InMemorySavepointManager - Class in org.apache.openjpa.kernel
A SavepointManager implementation which stores all data in memory.
InMemorySavepointManager() - Constructor for class org.apache.openjpa.kernel.InMemorySavepointManager
 
innerIdentityClasses - Variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool.Flags
 
innerJoinClause - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
insert(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
insert(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
 
insert(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
insert(OpenJPAStateManager, JDBCStore, RowManager) - Method in interface org.apache.openjpa.jdbc.meta.Strategy
Set values for the mapping into the proper rows.
insert(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractStrategy
 
insert(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.ColumnVersionStrategy
 
insert(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedFieldStrategy
 
insert(OpenJPAStateManager, OpenJPAStateManager, JDBCStore, RowManager, Row) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedFieldStrategy
Insert an embedded object.
insert(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.FullClassStrategy
 
insert(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
insert(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.InValueDiscriminatorStrategy
 
insert(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.NoneClassStrategy
 
insert(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
insert(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
insert(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyInverseKeyFieldStrategy
 
insert(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyTableFieldStrategy
 
insert(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy
 
insert(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
insert(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.VerticalClassStrategy
 
insert(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.Version
 
insert(WaitQueue.WaitNode) - Method in class org.apache.openjpa.lib.util.concurrent.WaitQueue
 
insertElementAt(Object, int) - Method in class org.apache.openjpa.util.ProxyVector
 
insertPlaceholder(String, int) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
Insert a placeholder at the given index; use a negative index to count from the back of the select list.
insertRow() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
insertsAreDetected(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
installDBDictionary(DBDictionary, DecoratingDataSource, JDBCConfiguration, boolean) - Static method in class org.apache.openjpa.jdbc.schema.DataSourceFactory
Install things deferred until the DBDictionary instance is available.
installPrimaryKey(FieldMapping, Table) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
If desired, install a primary key on the given secondary table.
installPrimaryKey(FieldMapping, Table) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
installPrimaryKey(FieldMapping, Table) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
installStrategy(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.MappingStrategyInstaller
 
installStrategy(FieldMapping) - Method in class org.apache.openjpa.jdbc.meta.MappingStrategyInstaller
 
installStrategy(Version) - Method in class org.apache.openjpa.jdbc.meta.MappingStrategyInstaller
 
installStrategy(Discriminator) - Method in class org.apache.openjpa.jdbc.meta.MappingStrategyInstaller
 
installStrategy(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.NoneStrategyInstaller
 
installStrategy(FieldMapping) - Method in class org.apache.openjpa.jdbc.meta.NoneStrategyInstaller
 
installStrategy(Version) - Method in class org.apache.openjpa.jdbc.meta.NoneStrategyInstaller
 
installStrategy(Discriminator) - Method in class org.apache.openjpa.jdbc.meta.NoneStrategyInstaller
 
installStrategy(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.RefreshStrategyInstaller
 
installStrategy(FieldMapping) - Method in class org.apache.openjpa.jdbc.meta.RefreshStrategyInstaller
 
installStrategy(Version) - Method in class org.apache.openjpa.jdbc.meta.RefreshStrategyInstaller
 
installStrategy(Discriminator) - Method in class org.apache.openjpa.jdbc.meta.RefreshStrategyInstaller
 
installStrategy(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.RuntimeStrategyInstaller
 
installStrategy(FieldMapping) - Method in class org.apache.openjpa.jdbc.meta.RuntimeStrategyInstaller
 
installStrategy(Version) - Method in class org.apache.openjpa.jdbc.meta.RuntimeStrategyInstaller
 
installStrategy(Discriminator) - Method in class org.apache.openjpa.jdbc.meta.RuntimeStrategyInstaller
 
installStrategy(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.StrategyInstaller
Install a strategy on the given mapping.
installStrategy(FieldMapping) - Method in class org.apache.openjpa.jdbc.meta.StrategyInstaller
Install a strategy on the given mapping.
installStrategy(Version) - Method in class org.apache.openjpa.jdbc.meta.StrategyInstaller
Install a strategy on the given mapping.
installStrategy(Discriminator) - Method in class org.apache.openjpa.jdbc.meta.StrategyInstaller
Install a strategy on the given mapping.
InstanceResultObjectProvider - Class in org.apache.openjpa.jdbc.kernel
Object provider implementation wrapped around a Select.
InstanceResultObjectProvider(SelectExecutor, ClassMapping, JDBCStore, JDBCFetchConfiguration) - Constructor for class org.apache.openjpa.jdbc.kernel.InstanceResultObjectProvider
Constructor.
instantiate(Class, Configuration, boolean) - Method in class org.apache.openjpa.conf.RemoteCommitProviderValue
Override to keep decorators out of transport configuration.
instantiate(Class, Configuration) - Method in class org.apache.openjpa.lib.conf.ObjectValue
Instantiate the object as an instance of the given class.
instantiate(Class, Configuration, boolean) - Method in class org.apache.openjpa.lib.conf.ObjectValue
Instantiate the object as an instance of the given class.
instantiate(Class, Configuration, boolean) - Method in class org.apache.openjpa.lib.conf.PluginListValue
Instantiate the plugins as instances of the given class.
instantiate(Class, Configuration, boolean) - Method in class org.apache.openjpa.lib.conf.PluginValue
Instantiate the plugin as an instance of the given class.
instantiate(ClassLoader) - Method in class org.apache.openjpa.meta.SequenceMetaData
Create a new uninitialized instance of this sequence.
instantiateAll() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
instantiateAll() - Method in interface org.apache.openjpa.lib.conf.Configuration
Call the instantiating get methods for all values.
instantiateAll() - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
instantiateClassStrategy(String, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Return the strategy for the given name.
instantiateDiscriminatorStrategy(String, Discriminator) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Instantiate the given discriminator strategy.
instantiateMetaDataFactory(Configuration, PluginValue, String) - Method in class org.apache.openjpa.jdbc.conf.MappingFactoryValue
Intantiate a MetaDataFactory responsible for both metadata and mapping.
instantiateMetaDataFactory(Configuration, PluginValue, String, boolean) - Method in class org.apache.openjpa.jdbc.conf.MappingFactoryValue
Intantiate a MetaDataFactory responsible for both metadata and mapping.
instantiateProvider(Configuration) - Method in class org.apache.openjpa.conf.RemoteCommitProviderValue
Instantiate the provider.
instantiateProvider(Configuration, boolean) - Method in class org.apache.openjpa.conf.RemoteCommitProviderValue
Instantiate the provider.
instantiateVersionStrategy(String, Version) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Instantiate the given version strategy.
instantiateVersionStrategy(Class, Version, String) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Instantiate the given version strategy.
INT - Static variable in class org.apache.openjpa.meta.JavaTypes
 
INT_OBJ - Static variable in class org.apache.openjpa.meta.JavaTypes
 
integerTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
InterbaseDictionary - Class in org.apache.openjpa.jdbc.sql
Dictionary for Borland Interbase.
InterbaseDictionary() - Constructor for class org.apache.openjpa.jdbc.sql.InterbaseDictionary
 
INTERNAL - Static variable in interface org.apache.openjpa.util.ExceptionInfo
 
InternalException - Exception in org.apache.openjpa.util
Exception type for internal errors.
InternalException() - Constructor for exception org.apache.openjpa.util.InternalException
 
InternalException(String) - Constructor for exception org.apache.openjpa.util.InternalException
 
InternalException(Localizer.Message) - Constructor for exception org.apache.openjpa.util.InternalException
 
InternalException(Throwable) - Constructor for exception org.apache.openjpa.util.InternalException
 
InternalException(String, Throwable) - Constructor for exception org.apache.openjpa.util.InternalException
 
InternalException(Localizer.Message, Throwable) - Constructor for exception org.apache.openjpa.util.InternalException
 
IntId - Class in org.apache.openjpa.util
OpenJPAId subclass appropriate for int fields.
IntId(Class, Integer) - Constructor for class org.apache.openjpa.util.IntId
 
IntId(Class, String) - Constructor for class org.apache.openjpa.util.IntId
 
IntId(Class, int) - Constructor for class org.apache.openjpa.util.IntId
 
IntId(Class, int, boolean) - Constructor for class org.apache.openjpa.util.IntId
 
IntValue - Class in org.apache.openjpa.lib.conf
An int Value.
IntValue(String) - Constructor for class org.apache.openjpa.lib.conf.IntValue
 
INVALID_STATE - Static variable in exception org.apache.openjpa.util.UserException
 
invalidateCompilation() - Method in class org.apache.openjpa.datacache.QueryCacheStoreQuery
 
invalidateCompilation() - Method in class org.apache.openjpa.kernel.AbstractStoreQuery
 
invalidateCompilation() - Method in class org.apache.openjpa.kernel.ExpressionStoreQuery
 
invalidateCompilation() - Method in class org.apache.openjpa.kernel.MethodStoreQuery
 
invalidateCompilation() - Method in interface org.apache.openjpa.kernel.StoreQuery
Invalidate any internal compilation state.
InvalidStateException - Exception in org.apache.openjpa.persistence
Extended IllegalStateException.
InvalidStateException(Localizer.Message, Throwable[], Object, boolean) - Constructor for exception org.apache.openjpa.persistence.InvalidStateException
 
InvalidStateException(String, Throwable[], Object, boolean) - Constructor for exception org.apache.openjpa.persistence.InvalidStateException
 
InvalidStateException - Exception in org.apache.openjpa.util
Exception type thrown when attempting to execute an operation that is not allowed by the current state.
InvalidStateException(Localizer.Message) - Constructor for exception org.apache.openjpa.util.InvalidStateException
 
InvalidStateException(Localizer.Message, Object) - Constructor for exception org.apache.openjpa.util.InvalidStateException
 
InValueDiscriminatorStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Base discriminator strategy that determines the class of database records using a column holding a value mapped to a class, and limits SELECTs using an IN (...) statement.
InValueDiscriminatorStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.InValueDiscriminatorStrategy
 
InverseLogical - Annotation Type in org.apache.openjpa.persistence
Declares the logical inverse of a field.
InverseManager - Class in org.apache.openjpa.kernel
Class which manages inverse relations before flushing to the datastore.
InverseManager() - Constructor for class org.apache.openjpa.kernel.InverseManager
 
inverseManagerPlugin - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
inverseRelations - Variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool.Flags
 
InvocationManagedRuntime - Class in org.apache.openjpa.ee
Implementation of the ManagedRuntime interface that uses a static method call to find the TransactionManager.
InvocationManagedRuntime() - Constructor for class org.apache.openjpa.ee.InvocationManagedRuntime
 
isAccessibleField(String) - Method in class org.apache.openjpa.meta.ClassMetaData
Return whether the given name represents a managed or static field of this class, including superclass fields.
isAccessPathDirty(Broker, ClassMetaData[]) - Static method in class org.apache.openjpa.kernel.QueryImpl
 
isActive() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
isActive() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
isActive() - Method in interface org.apache.openjpa.kernel.StoreContext
Whether a logical transaction is active.
isActive() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
isAdapting() - Method in class org.apache.openjpa.jdbc.meta.MappingStrategyInstaller
 
isAdapting() - Method in class org.apache.openjpa.jdbc.meta.RefreshStrategyInstaller
 
isAdapting() - Method in class org.apache.openjpa.jdbc.meta.StrategyInstaller
Return whether this installer adapts the given mapping data and schema, vs requiring that all information be supplied correctly.
isAfterLast() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
isAggregate() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
isAggregate() - Method in interface org.apache.openjpa.jdbc.sql.Select
Return true if this is an aggregate select.
isAggregate() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
isAggregate(StoreQuery) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery.AbstractExecutor
 
isAggregate() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
isAggregate() - Method in class org.apache.openjpa.kernel.exps.QueryExpressions
Whether this is an aggregate results.
isAggregate() - Method in class org.apache.openjpa.kernel.exps.Val
 
isAggregate() - Method in interface org.apache.openjpa.kernel.exps.Value
Return true if this value is an aggregate.
isAggregate() - Method in interface org.apache.openjpa.kernel.QueryContext
Return true if the query is an aggregate.
isAggregate() - Method in class org.apache.openjpa.kernel.QueryImpl
 
isAggregate(StoreQuery) - Method in interface org.apache.openjpa.kernel.StoreQuery.Executor
Return true if the compiled query is an aggregate.
isAliasListComprehensive() - Method in class org.apache.openjpa.lib.conf.Value
Whether or not the alias list defines all possible settings for this value.
isAllInsertable(int, boolean) - Method in class org.apache.openjpa.jdbc.schema.ColumnIO
Whether all columns up to but excluding the given index are insertable.
isAllInsertable(Column[], boolean) - Method in class org.apache.openjpa.jdbc.schema.ColumnIO
Equivalent to isAllInsertable (cols.length, nullValue).
isAllInsertable(ForeignKey, boolean) - Method in class org.apache.openjpa.jdbc.schema.ColumnIO
Return true if all columns for the given key are insertable.
isAllUpdatable(int, boolean) - Method in class org.apache.openjpa.jdbc.schema.ColumnIO
Whether all columns up to but excluding the given index are updatable.
isAllUpdatable(Column[], boolean) - Method in class org.apache.openjpa.jdbc.schema.ColumnIO
Equivalent to isAllUpdatable (cols.length, nullValue).
isAllUpdatable(ForeignKey, boolean) - Method in class org.apache.openjpa.jdbc.schema.ColumnIO
Return true if all columns for the given key are updatable.
isAnnotation(Class) - Static method in class org.apache.openjpa.lib.util.JavaVersions
Return true if the given type is an annotation.
isAnyInsertable(int, boolean) - Method in class org.apache.openjpa.jdbc.schema.ColumnIO
Whether any column up to but excluding the given index is insertable.
isAnyInsertable(Column[], boolean) - Method in class org.apache.openjpa.jdbc.schema.ColumnIO
Equivalent to isAnyInsertable (cols.length, nullValue).
isAnyInsertable(ForeignKey, boolean) - Method in class org.apache.openjpa.jdbc.schema.ColumnIO
Return true if any columns for the given key are insertable.
isAnyUpdatable(int, boolean) - Method in class org.apache.openjpa.jdbc.schema.ColumnIO
Whether any column up to but excluding the given index is updatable.
isAnyUpdatable(Column[], boolean) - Method in class org.apache.openjpa.jdbc.schema.ColumnIO
Equivalent to isAnyUpdatable (cols.length, nullValue).
isAnyUpdatable(ForeignKey, boolean) - Method in class org.apache.openjpa.jdbc.schema.ColumnIO
Return true if any columns for the given key are updatable.
isAscending() - Method in interface org.apache.openjpa.meta.Order
Order direction.
isAutoAssigned() - Method in class org.apache.openjpa.jdbc.schema.Column
Whether this column is auto-assigned a value on insert.
isBaseTable(Table) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Return whether the given table is a base class table.
isBeforeFirst() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
isBound(Value) - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
Return true if the given variable has been bound.
isCaching() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Whether parsed resource names are cached to avoid duplicate parsing.
isCatalogAtStart() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
isClassElementName(String) - Method in class org.apache.openjpa.lib.meta.CFMetaDataParser
The name of the class element.
isClassElementName(String) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
isClosed() - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
isClosed() - Method in class org.apache.openjpa.datacache.AbstractQueryCache
 
isClosed() - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
Returns true if this broker factory is closed.
isClosed() - Method in interface org.apache.openjpa.kernel.Broker
Whether the broker is closed.
isClosed() - Method in interface org.apache.openjpa.kernel.BrokerFactory
Returns true if this broker factory is closed.
isClosed() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
isClosed() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
isClosed() - Method in class org.apache.openjpa.kernel.DelegatingBrokerFactory
 
isClosed() - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
isClosed() - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
isClosed() - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
isClosed() - Method in class org.apache.openjpa.lib.rop.LazyForwardResultList
 
isClosed() - Method in class org.apache.openjpa.lib.rop.ListResultList
 
isClosed() - Method in class org.apache.openjpa.lib.rop.RandomAccessResultList
 
isClosed() - Method in interface org.apache.openjpa.lib.rop.ResultList
Returns true if the list has been closed.
isClosed() - Method in class org.apache.openjpa.lib.rop.SimpleResultList
 
isClosed() - Method in class org.apache.openjpa.lib.rop.WindowResultList
 
isCompatible(int, int) - Method in class org.apache.openjpa.enhance.DynamicStorageGenerator
Return true if the given field type and storage type are compatible.
isCompatible(int, int) - Method in class org.apache.openjpa.jdbc.schema.Column
Return true if this column is compatible with the given JDBC type from Types and size.
isConnectionFactoryModeManaged() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Whether connections are automatically enlisted in global transactions.
isConnectionFactoryModeManaged() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
isConstant() - Method in interface org.apache.openjpa.jdbc.kernel.exps.FilterValue
Return true if this value represents a literal or parameter.
isCustom(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedBlobFieldStrategy
 
isCustom(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedByteArrayFieldStrategy
 
isCustom(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedCharArrayFieldStrategy
 
isCustom(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedClobFieldStrategy
 
isCustomDelete(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
isCustomDelete(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
 
isCustomDelete(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
isCustomDelete(OpenJPAStateManager, JDBCStore) - Method in interface org.apache.openjpa.jdbc.meta.Strategy
Return Boolean.FALSE if this mapping does not customize the delete process, Boolean.TRUE if it does, or null if it does customize the delete, but also relies on the standard delete method being called.
isCustomDelete(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractStrategy
 
isCustomDelete(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedFieldStrategy
 
isCustomDelete(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.Version
 
isCustomInsert(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
isCustomInsert(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
 
isCustomInsert(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
isCustomInsert(OpenJPAStateManager, JDBCStore) - Method in interface org.apache.openjpa.jdbc.meta.Strategy
Return Boolean.FALSE if this mapping does not customize the insert process, Boolean.TRUE if it does, or null if it does customize the insert, but also relies on the standard insert method being called.
isCustomInsert(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractStrategy
 
isCustomInsert(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedFieldStrategy
 
isCustomInsert(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.Version
 
isCustomUpdate(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
isCustomUpdate(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
 
isCustomUpdate(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
isCustomUpdate(OpenJPAStateManager, JDBCStore) - Method in interface org.apache.openjpa.jdbc.meta.Strategy
Return Boolean.FALSE if this mapping does not customize the update process, Boolean.TRUE if it does, or null if it does customize the update, but also relies on the standard update method being called.
isCustomUpdate(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractStrategy
 
isCustomUpdate(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedFieldStrategy
 
isCustomUpdate(OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.Version
 
isDataStoreObjectIdFieldUnwrapped() - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
 
isDataStoreObjectIdFieldUnwrapped() - Method in interface org.apache.openjpa.meta.MetaDataDefaults
Whether the field in the object id class corresponding to a datastore id persistence-capable primary key field is the simple datastore id value of the related instance.
isDataStoreObjectIdFieldUnwrapped() - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
isDeclaredInterfacePersistent() - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
 
isDeclaredInterfacePersistent() - Method in interface org.apache.openjpa.meta.MetaDataDefaults
Whether declared interfaces of a class are treated as persistent types.
isDeclaredInterfacePersistent() - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
isDeclaredTypePC() - Method in class org.apache.openjpa.meta.FieldMetaData
 
isDeclaredTypePC() - Method in interface org.apache.openjpa.meta.ValueMetaData
Whether the type is a persistence capable instance.
isDeclaredTypePC() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
isDeclaredVariable(String) - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
Returns whether the specified variable name has been explicitly declared.
isDefaultFetchGroupExplicit() - Method in class org.apache.openjpa.meta.FieldMetaData
Whether the default fetch group setting is explicit.
isDefaultPersistent(ClassMetaData, Member, String) - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
Return true if the given member is persistent by default.
isDefaultPersistent(ClassMetaData, Member, String) - Method in class org.apache.openjpa.persistence.PersistenceMetaDataDefaults
 
isDefaultValue(int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
isDefaultValue(int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
isDefaultValue(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
isDefaultValue(int) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return true if the given field has a default value.
isDefaultValue(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
isDeferred() - Method in class org.apache.openjpa.jdbc.schema.Constraint
Return true if this is a deferred constraint.
isDeleted() - Method in interface org.apache.openjpa.enhance.StateManager
Whether the instance is deleted in this transaction.
isDeleted(Object) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
isDeleted(Object) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
isDeleted() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
isDeleted() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
isDeleted() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
isDeleted() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
isDeleted(Object) - Method in interface org.apache.openjpa.kernel.StoreContext
Return whether the given object is deleted.
isDependent() - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
Mark this row as dependent on some other row.
isDependent() - Method in class org.apache.openjpa.jdbc.sql.RowImpl
Secondary rows cannot be dependent.
isDetachable() - Method in class org.apache.openjpa.meta.ClassMetaData
Whether instances are detachable.
isDetached() - Method in interface org.apache.openjpa.enhance.StateManager
Whether the instance is detached (i.e.
isDetached(Object) - Method in interface org.apache.openjpa.kernel.Broker
Returns true if obj is a detached object (one that can be reattached to a Broker via a call to Broker.attach(java.lang.Object, boolean, org.apache.openjpa.kernel.OpCallbacks)); otherwise returns false.
isDetached(Object) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
isDetached(Object) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
isDetached() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
isDetached() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
isDetached() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
isDetached() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
isDetached(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
isDetached(Object) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Returns true if pc is a detached object (one that can be reattached to a EntityManager via a call to EntityManager.merge(T)); otherwise returns false.
isDetachedNew() - Method in interface org.apache.openjpa.kernel.Broker
Whether to treat relations to detached instances during persist operations as new or as pseudo-hollow instances.
isDetachedNew() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
isDetachedNew() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
isDetachedStateTransient() - Method in class org.apache.openjpa.conf.DetachOptions
Whether to use transient detached state.
isDirty() - Method in interface org.apache.openjpa.enhance.StateManager
Whether the instance has been modified in this transaction.
isDirty() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
isDirty() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
isDirty(Object) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
isDirty(Object) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
isDirty() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
isDirty() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
isDirty() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
isDirty() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
isDirty(Object) - Method in interface org.apache.openjpa.kernel.StoreContext
Return whether the given object is dirty.
isDirty(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
isDirty(Object) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return whether the given object is dirty.
isDistinct() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
isDistinct() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
isDistinct() - Method in interface org.apache.openjpa.jdbc.sql.SelectExecutor
Whether this is a SELECT DISTINCT / UNION ALL.
isDistinct() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
isEagerSelectToMany() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
isEagerSelectToMany() - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Whether the eager joins or selects used by this field are to-many.
isEagerSelectToMany() - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
isEagerSelectToMany() - Method in class org.apache.openjpa.jdbc.meta.strats.StoreCollectionFieldStrategy
 
isEmbedded() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
isEmbedded() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
isEmbedded() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
isEmbedded() - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return true if this instance has an owner, meaning it is an embedded value.
isEmbedded() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
isEmbedded() - Method in class org.apache.openjpa.meta.FieldMetaData
 
isEmbedded() - Method in interface org.apache.openjpa.meta.ValueMetaData
This attribute is a hint to the implementation to store this value in the same structure as the class, rather than as a separate datastore structure.
isEmbedded() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
isEmbeddedOnly() - Method in class org.apache.openjpa.meta.ClassMetaData
Whether the type can only be used as an embedded object.
isEmbeddedPC() - Method in class org.apache.openjpa.meta.FieldMetaData
 
isEmbeddedPC() - Method in interface org.apache.openjpa.meta.ValueMetaData
Whether this is an embedded persistence capable value.
isEmbeddedPC() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
isEmpty(Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
isEmpty() - Method in interface org.apache.openjpa.jdbc.sql.Joins
Whether we have any joins.
isEmpty() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
isEmpty() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
isEmpty() - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Return true if the buffer is emtpy.
isEmpty() - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
isEmpty(Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return an expression representing the given condition.
isEmpty(Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
isEmpty() - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
isEmpty() - Method in class org.apache.openjpa.lib.rop.AbstractNonSequentialResultList
 
isEmpty() - Method in class org.apache.openjpa.lib.rop.AbstractSequentialResultList
 
isEmpty() - Method in class org.apache.openjpa.lib.rop.ListResultList
 
isEmpty() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
Returns true if this map contains no key-value mappings.
isEmpty() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashSet
 
isEmpty() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentLinkedQueue
Returns true if this queue contains no elements.
isEmpty() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
Returns true if this Map contains no key-value mappings.
isEmpty() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashSet
 
isEmpty() - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
isEmpty() - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArraySet
Returns true if this set contains no elements.
isEmpty() - Method in class org.apache.openjpa.lib.util.MultiClassLoader
Return true if there are no internal class laoders.
isEmpty() - Method in class org.apache.openjpa.lib.util.ReferenceHashSet
 
isEmpty() - Method in class org.apache.openjpa.meta.Extensions
Return true if there are no keys for any vendor.
isEmpty() - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
isEmpty() - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
isEmpty() - Method in class org.apache.openjpa.util.CacheMap
 
isEnabled(short) - Method in class org.apache.openjpa.lib.log.AbstractLog
Check to see if the specified logging level is enabled.
isEnabled(short) - Method in class org.apache.openjpa.lib.log.LogFactoryImpl.LogImpl
 
isEnumeration(Class) - Static method in class org.apache.openjpa.lib.util.JavaVersions
Return true if the given type is an enumeration.
isErrorEnabled() - Method in class org.apache.openjpa.lib.log.AbstractLog
 
isErrorEnabled() - Method in class org.apache.openjpa.lib.log.CommonsLogFactory.LogAdapter
 
isErrorEnabled() - Method in interface org.apache.openjpa.lib.log.Log
Returns if the Log.ERROR log level is enabled.
isErrorEnabled() - Method in class org.apache.openjpa.lib.log.Log4JLogFactory.LogAdapter
 
isErrorEnabled() - Method in class org.apache.openjpa.lib.log.NoneLogFactory.NoneLog
 
isExplicit() - Method in class org.apache.openjpa.meta.FieldMetaData
Whether this field is explicitly declared in the metadata.
isExtent() - Method in class org.apache.openjpa.jdbc.kernel.exps.SelectConstructor
Return true if we know the select to have on criteria; to be an extent.
isExternalized() - Method in class org.apache.openjpa.meta.FieldMetaData
Whether the field is externalized.
isFailFast() - Method in class org.apache.openjpa.event.LifecycleEventManager
Whether to fail after first exception when firing events to listeners.
isFailFast() - Method in class org.apache.openjpa.lib.util.concurrent.AbstractConcurrentEventManager
Whether to fail after the first exception thrown by any listener.
isFair() - Method in class org.apache.openjpa.lib.util.concurrent.ReentrantLock
Returns true if this lock has fairness set true.
isFatal() - Method in exception org.apache.openjpa.persistence.ArgumentException
 
isFatal() - Method in exception org.apache.openjpa.persistence.EntityExistsException
 
isFatal() - Method in exception org.apache.openjpa.persistence.EntityNotFoundException
 
isFatal() - Method in exception org.apache.openjpa.persistence.InvalidStateException
 
isFatal() - Method in exception org.apache.openjpa.persistence.NonUniqueResultException
 
isFatal() - Method in exception org.apache.openjpa.persistence.NoResultException
 
isFatal() - Method in exception org.apache.openjpa.persistence.OptimisticLockException
 
isFatal() - Method in exception org.apache.openjpa.persistence.PersistenceException
 
isFatal() - Method in exception org.apache.openjpa.persistence.RollbackException
 
isFatal() - Method in exception org.apache.openjpa.persistence.TransactionRequiredException
 
isFatal() - Method in interface org.apache.openjpa.util.ExceptionInfo
Whether this error is fatal.
isFatal() - Method in exception org.apache.openjpa.util.OpenJPAException
Whether this error is fatal.
isFatalEnabled() - Method in class org.apache.openjpa.lib.log.AbstractLog
 
isFatalEnabled() - Method in class org.apache.openjpa.lib.log.CommonsLogFactory.LogAdapter
 
isFatalEnabled() - Method in interface org.apache.openjpa.lib.log.Log
Returns if the Log.FATAL log level is enabled.
isFatalEnabled() - Method in class org.apache.openjpa.lib.log.Log4JLogFactory.LogAdapter
 
isFatalEnabled() - Method in class org.apache.openjpa.lib.log.NoneLogFactory.NoneLog
 
isFinal - Variable in class org.apache.openjpa.jdbc.meta.strats.AbstractDiscriminatorStrategy
Whether the owning class is final.
isFirst() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
isFlushed() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
isFlushed() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
isFlushed() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
isFlushed() - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return whether this object has been flushed to the datastore in this transaction.
isFlushed() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
isFlushedDirty() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
isFlushedDirty() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
isFlushedDirty() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
isFlushedDirty() - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return whether this object has been flushed, then dirtied again.
isFlushedDirty() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
isForeignKeyInversed() - Method in class org.apache.openjpa.jdbc.sql.Join
 
isForeignKeyObjectId(ForeignKey) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Return whether the columns of the given foreign key to this mapping can be used to construct an object id for this type.
isFull() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
 
isFull() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
 
isFull() - Method in class org.apache.openjpa.lib.util.LRUMap
 
isFull() - Method in class org.apache.openjpa.lib.util.ReferenceHashMap
 
isFull() - Method in interface org.apache.openjpa.lib.util.SizedMap
Whether the map is full.
isHeldByCurrentThread() - Method in class org.apache.openjpa.lib.util.concurrent.ReentrantLock
Queries if this lock is held by the current thread.
isImage(Object) - Static method in class org.apache.openjpa.util.ArrayStateImage
Return true if the given version object appears to be an array state image.
isImplDataCacheable() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
isImplDataCacheable(int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
isImplDataCacheable() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
isImplDataCacheable(int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
isImplDataCacheable() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
isImplDataCacheable(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
isImplDataCacheable() - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Whether the instance-level impl data can be shared among instances in different contexts if L2 caching is enabled.
isImplDataCacheable(int) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Whether the field's impl data is loaded and can be shared among instances in different contexts if L2 caching is enabled.
isImplDataCacheable() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
isImplDataCacheable(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
isInDefaultFetchGroup() - Method in class org.apache.openjpa.meta.FieldMetaData
Whether this field is in the default fetch group.
isInFetchGroup(String) - Method in class org.apache.openjpa.meta.FieldMetaData
Whether this field is in the given fetch group.
isInfoEnabled() - Method in class org.apache.openjpa.lib.log.AbstractLog
 
isInfoEnabled() - Method in class org.apache.openjpa.lib.log.CommonsLogFactory.LogAdapter
 
isInfoEnabled() - Method in interface org.apache.openjpa.lib.log.Log
Returns if the Log.INFO log level is enabled.
isInfoEnabled() - Method in class org.apache.openjpa.lib.log.Log4JLogFactory.LogAdapter
 
isInfoEnabled() - Method in class org.apache.openjpa.lib.log.NoneLogFactory.NoneLog
 
isInnerClass() - Method in class org.apache.openjpa.enhance.ApplicationIdTool
Returns true if the application identity class should be an inner class.
isInsertable(int, boolean) - Method in class org.apache.openjpa.jdbc.schema.ColumnIO
Whether the column at the given index is insertable in this context.
isInsertable(Column, boolean) - Method in class org.apache.openjpa.jdbc.schema.ColumnIO
Equivalent to isInsertable (0, nullValue), but returns false if the given column is null.
isInstance(Value, Class) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
isInstance(Value, Class) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return whether the first value is an instance of the given class.
isInstance(Value, Class) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
isInvalidProperty(String) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
isInvalidProperty(String) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
Returns true if the specified property name should raise a warning if it is not found in the list of known properties.
isJDBCEnabled() - Method in class org.apache.openjpa.lib.jdbc.DataSourceLogs
Return true if JDBC logging is enabled.
isJoinedSubclass() - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
Whether there is a join to the superclass table.
isJoinOuter() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Whether to use an outer join from the class' primary table.
isJoinOuter() - Method in class org.apache.openjpa.jdbc.meta.FieldMappingInfo
Whether the field's table is joined to the class table through an outer join.
isKnownSequence(Sequence) - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Return true if the given sequence is known to exist.
isKnownSequence(String) - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Return true if the given sequence is known to exist.
isKnownTable(Table) - Method in class org.apache.openjpa.jdbc.schema.DynamicSchemaFactory
 
isKnownTable(String) - Method in class org.apache.openjpa.jdbc.schema.DynamicSchemaFactory
 
isKnownTable(Table) - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Return true if the given table is known to exist.
isKnownTable(String) - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Return true if the given table is known to exist.
isLargeTransaction() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
isLargeTransaction() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
isLargeTransaction() - Method in interface org.apache.openjpa.kernel.StoreContext
Whether memory usage is reduced during this transaction at the expense of possibly more aggressive data cache evictions.
isLargeTransaction() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
isLargeTransaction() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether memory usage is reduced during this transaction at the expense of possibly more aggressive data cache evictions.
isLast() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
isLoaded(int) - Method in class org.apache.openjpa.datacache.DataCachePCDataImpl
 
isLoaded(int) - Method in class org.apache.openjpa.kernel.AbstractPCData
 
isLoaded(int) - Method in interface org.apache.openjpa.kernel.PCData
Whether the given field index has stored data.
isLoaded(int) - Method in class org.apache.openjpa.kernel.PCDataImpl
 
isLob() - Method in class org.apache.openjpa.jdbc.schema.Column
Whether this column is a LOB.
isLob() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
isLob() - Method in interface org.apache.openjpa.jdbc.sql.Select
Return true if this select includes a LOB.
isLob() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
isLocked() - Method in class org.apache.openjpa.lib.util.concurrent.ReentrantLock
Queries if this lock is held by any thread.
isLocking() - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
isLocking() - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
isLocking() - Method in interface org.apache.openjpa.jdbc.sql.Result
If true, then any results loaded from this Result will be locked in the database.
isLogical() - Method in class org.apache.openjpa.jdbc.schema.Constraint
Return whether this constraint is a logical constraint only; i.e.
isLogical() - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
 
isLogical() - Method in class org.apache.openjpa.jdbc.schema.Index
 
isLogical() - Method in class org.apache.openjpa.jdbc.schema.PrimaryKey
 
isLogical() - Method in class org.apache.openjpa.jdbc.schema.Unique
 
isLRS() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
isLRS() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
isLRS() - Method in interface org.apache.openjpa.jdbc.sql.SelectExecutor
Whether the result of this select should be treated as a large result set.
isLRS() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
isLRS() - Method in class org.apache.openjpa.meta.FieldMetaData
Whether this field is backed by a large result set.
isLRU() - Method in class org.apache.openjpa.util.CacheMap
Whether this cache map uses LRU eviction.
isManageable(Object) - Static method in class org.apache.openjpa.util.ImplHelper
Returns true if the specified instance is manageable.
isManaged() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
isManaged() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
isManaged() - Method in interface org.apache.openjpa.kernel.StoreContext
Whether this context is using managed transactions.
isManaged() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
isManaged() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether this entity manager is using managed transactions.
isManagedInterface() - Method in class org.apache.openjpa.meta.ClassMetaData
Whether the type is a managed interface.
isManagedType(EntityManager, Class) - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
Returns true if the specified class is an entity or embeddable type.
isManagedType(EntityManagerFactory, Class) - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
Returns true if the specified class is an entity or embeddable type.
isManagedType(Class) - Static method in class org.apache.openjpa.util.ImplHelper
Returns true if the specified class is a type that can be managed by OpenJPA.
isMapped() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Returns true if this class does not use the "none" strategy (including if it has a null strategy, and therefore is probably in the process of being mapped).
isMapped() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Returns true if field class does not use the "none" strategy (including if it has a null strategy, and therefore is probably in the process of being mapped).
isMapped() - Method in class org.apache.openjpa.meta.ClassMetaData
Whether this class is mapped to the datastore.
isMapped() - Method in class org.apache.openjpa.meta.FieldMetaData
Return whether this field is mapped to the datastore.
isMappingMode() - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Convenience method for interpreting AnnotationPersistenceMetaDataParser.getMode().
isMappingMode() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Convenience method for interpreting XMLPersistenceMetaDataParser.getMode().
isMappingMode() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Convenience method for interpreting XMLPersistenceMetaDataSerializer.getMode().
isMappingMode(ClassMetaData) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Convenience method for interpreting XMLPersistenceMetaDataSerializer.getMode().
isMappingMode(ValueMetaData) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Convenience method for interpreting XMLPersistenceMetaDataSerializer.getMode().
isMappingOnlyFactory() - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Return true if this factory deals only with mapping data, and relies on a separate factory for metadata.
isMappingOverrideMode() - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Returns true if we're in mapping mode or in metadata mode with mapping overide enabled.
isMappingOverrideMode() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Returns true if we're in mapping mode or in metadata mode with mapping override enabled.
isMetaDataAction() - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Whether the action works on metadata as well as mappings.
isMetaDataMode() - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Convenience method for interpreting AnnotationPersistenceMetaDataParser.getMode().
isMetaDataMode() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Convenience method for interpreting XMLPersistenceMetaDataParser.getMode().
isMetaDataMode() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Convenience method for interpreting XMLPersistenceMetaDataSerializer.getMode().
isNameTaken(String) - Method in class org.apache.openjpa.jdbc.schema.NameSet
Return true if the given name is in use already.
isNew() - Method in interface org.apache.openjpa.enhance.StateManager
Whether the instance is newly-persisted in this transaction.
isNew(Object) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
isNew(Object) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
isNew() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
isNew() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
isNew() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
isNew() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
isNew(Object) - Method in interface org.apache.openjpa.kernel.StoreContext
Return whether the given object is a newly-created instance registered with broker.
isNewlyPersistent(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
isNewlyPersistent(Object) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return whether the given object was made persistent in the current transaction.
isNotEmpty(Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
isNotEmpty(Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return an expression representing the given condition.
isNotEmpty(Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
isNotNull() - Method in class org.apache.openjpa.jdbc.schema.Column
Return true if this is a NOT NULL column.
isNotNullExplicit() - Method in class org.apache.openjpa.jdbc.schema.Column
Whether the not-null property has been set.
isNullOnNoLocator() - Method in class org.apache.openjpa.lib.xml.Location
 
isObjectIdTypeShared() - Method in class org.apache.openjpa.meta.ClassMetaData
Whether this type uses an application identity class that is shared with other classes, and is therefore wrapped in an ObjectId.
isolate - Variable in class org.apache.openjpa.lib.ant.AbstractTask
 
isOpen() - Method in class org.apache.openjpa.persistence.EntityManagerFactoryImpl
 
isOpen() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
isOpenJPAIdentity() - Method in class org.apache.openjpa.meta.ClassMetaData
Whether this type uses OpenJPA identity.
isOuter() - Method in interface org.apache.openjpa.jdbc.sql.Joins
Whether this joins path results in outer joins.
isOuter() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
isOuter() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
isOwner(Proxy, OpenJPAStateManager, int) - Static method in class org.apache.openjpa.util.Proxies
Used by proxy types to check if the given owners and field names are equivalent.
isPackageElementName(String) - Method in class org.apache.openjpa.lib.meta.CFMetaDataParser
The name of the package element.
isPacking(StoreQuery) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery.AbstractExecutor
 
isPacking(StoreQuery) - Method in interface org.apache.openjpa.kernel.StoreQuery.Executor
Return true if this executor packs projections into the result class itself.
isParseTopDown() - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Whether to parse classes top down.
isPath() - Method in interface org.apache.openjpa.jdbc.kernel.exps.FilterValue
Return true if this value represents a persistent field traversal, such as 'this', 'address.street', or 'projectVariable.title'.
isPendingTransactional() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
isPersistent() - Method in interface org.apache.openjpa.enhance.StateManager
Whether the instance is persistent.
isPersistent(Object) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
isPersistent(Object) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
isPersistent() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
isPersistent() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
isPersistent() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
isPersistent() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
isPersistent(Object) - Method in interface org.apache.openjpa.kernel.StoreContext
Return whether the given object is persistent.
isPersistent(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
isPersistent(Object) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return whether the given object is persistent.
isPostLoad() - Method in class org.apache.openjpa.meta.FetchGroup
Whether loading this fetch group causes a post-load callback on the loaded instance.
isPostLoadExplicit() - Method in class org.apache.openjpa.meta.FetchGroup
Whether the post-load value is declared for this group.
isPrimaryKey() - Method in class org.apache.openjpa.jdbc.schema.Column
Return true if this column belongs to the table's primary key.
isPrimaryKey() - Method in class org.apache.openjpa.meta.FieldMetaData
Whether this is a primary key field.
isPrimaryKeyAutoAssigned() - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Whether the primary key columns of this key are auto-incrementing, or whether they themselves are members of a foreign key who's primary key is auto-incrementing (recursing to arbitrary depth).
isPrimaryKeyObjectId(boolean) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
isPrimaryKeyObjectId(boolean) - Method in interface org.apache.openjpa.jdbc.meta.ClassStrategy
Return true if the this class' primary key columns correspond to the base class' primary key columns used to construct oid values.
isPrimaryKeyObjectId(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractClassStrategy
 
isPrimaryKeyObjectId(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbeddedClassStrategy
 
isPrimaryKeyObjectId(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.FlatClassStrategy
 
isPrimaryKeyObjectId(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.FullClassStrategy
 
isPrimaryKeyObjectId(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.VerticalClassStrategy
 
isProviderOpen() - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
isProviderOpen() - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
isProviderOpen() - Method in class org.apache.openjpa.lib.rop.LazyForwardResultList
 
isProviderOpen() - Method in class org.apache.openjpa.lib.rop.ListResultList
 
isProviderOpen() - Method in class org.apache.openjpa.lib.rop.RandomAccessResultList
 
isProviderOpen() - Method in interface org.apache.openjpa.lib.rop.ResultList
Returns true if the provider backing this list is open.
isProviderOpen() - Method in class org.apache.openjpa.lib.rop.SimpleResultList
 
isProviderOpen() - Method in class org.apache.openjpa.lib.rop.WindowResultList
 
isProvisional() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
isProvisional() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
isProvisional() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
isProvisional() - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Return whether this object is provisionally persistent.
isProvisional() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
isQueryMode() - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Convenience method for interpreting AnnotationPersistenceMetaDataParser.getMode().
isQueryMode() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Convenience method for interpreting XMLPersistenceMetaDataParser.getMode().
isQueryMode() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Convenience method for interpreting XMLPersistenceMetaDataSerializer.getMode().
isReadOnly() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
isReadOnly() - Method in interface org.apache.openjpa.kernel.QueryContext
Whether the query has been marked read-only.
isReadOnly() - Method in class org.apache.openjpa.kernel.QueryImpl
 
isReadOnly() - Method in interface org.apache.openjpa.lib.conf.Configuration
Return true if this configuration is immutable.
isReadOnly() - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
isReadOnly() - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
isReadOnly() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
isReadOnly() - Method in class org.apache.openjpa.meta.QueryMetaData
Whether the query has been marked read-only.
isRegistered(Class) - Static method in class org.apache.openjpa.enhance.PCRegistry
Returns true if cls is already registered.
isRelationId() - Method in class org.apache.openjpa.jdbc.schema.Column
Whether this column stores some form of serialized identity value for a related record.
isRemoved(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
isRemoved(Object) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return whether the given object is deleted.
isReservedFieldName(String) - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
Returns true if the given field name is reserved for unmanaged fields.
isRuntime() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Return whether we're running the parser at runtime.
isSeenVariable(String) - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
Return whether the given id has been used as a variable.
isSelected(Table) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
isSelected(Table) - Method in interface org.apache.openjpa.jdbc.sql.Select
Return whether the given table is being used in this select.
isSelected(Table) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
isSerialized() - Method in class org.apache.openjpa.meta.FieldMetaData
 
isSerialized() - Method in interface org.apache.openjpa.meta.ValueMetaData
Whether this value is serialized when stored.
isSerialized() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
isSingleResult() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
isSingleResult() - Method in interface org.apache.openjpa.jdbc.sql.Union
Whether this union will return at most a single result.
isSingleton() - Method in class org.apache.openjpa.lib.conf.PluginValue
Whether this value is a singleton.
isSQLEnabled() - Method in class org.apache.openjpa.lib.jdbc.DataSourceLogs
Return true if SQL logging is enabled.
isStoreActive() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
isStoreActive() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
isStoreActive() - Method in interface org.apache.openjpa.kernel.StoreContext
Whether a data store transaction is active.
isStoreActive() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
isStoreActive() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether a store transaction is active.
isSystemIndex(String, Table) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
This method is used to filter system indexes from database metadata.
isSystemIndex(String, Table) - Method in class org.apache.openjpa.jdbc.sql.EmpressDictionary
 
isSystemIndex(String, Table) - Method in class org.apache.openjpa.jdbc.sql.HSQLDictionary
 
isSystemIndex(String, Table) - Method in class org.apache.openjpa.jdbc.sql.PostgresDictionary
 
isSystemSequence(String, String, boolean) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
This method is used to filter system sequences from database metadata.
isSystemSequence(String, String, boolean) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
isSystemSequence(String, String, boolean) - Method in class org.apache.openjpa.jdbc.sql.PostgresDictionary
 
isSystemTable(String, String, boolean) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
This method is used to filter system tables from database metadata.
isSystemTable(String, String, boolean) - Method in class org.apache.openjpa.jdbc.sql.PostgresDictionary
 
isTimedOut() - Method in interface org.apache.openjpa.datacache.DataCachePCData
Whether this data is timed out.
isTimedOut() - Method in class org.apache.openjpa.datacache.DataCachePCDataImpl
 
isTimedOut() - Method in class org.apache.openjpa.datacache.QueryResult
Whether this data is timed out.
isTraceEnabled() - Method in class org.apache.openjpa.lib.log.AbstractLog
 
isTraceEnabled() - Method in class org.apache.openjpa.lib.log.CommonsLogFactory.LogAdapter
 
isTraceEnabled() - Method in interface org.apache.openjpa.lib.log.Log
Returns if the Log.TRACE log level is enabled.
isTraceEnabled() - Method in class org.apache.openjpa.lib.log.Log4JLogFactory.LogAdapter
 
isTraceEnabled() - Method in class org.apache.openjpa.lib.log.NoneLogFactory.NoneLog
 
isTracking() - Method in class org.apache.openjpa.util.AbstractChangeTracker
 
isTracking() - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
isTracking() - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
isTracking() - Method in interface org.apache.openjpa.util.ChangeTracker
Return true if this tracker has an up-to-date view of all the changes to the container it is managing.
isTransactional() - Method in interface org.apache.openjpa.enhance.StateManager
Whether the instance is transactional.
isTransactional(Object) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
isTransactional(Object) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
isTransactional() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
isTransactional() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
isTransactional() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
isTransactional() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
isTransactional(Object) - Method in interface org.apache.openjpa.kernel.StoreContext
Return whether the given object is transactional.
isTransactional(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
isTransactional(Object) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Return whether the given object is transactional.
isTransactionModeManaged() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Return whether managed transactions are being used.
isTransactionModeManaged() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
isTransient() - Method in class org.apache.openjpa.meta.FieldMetaData
Return whether this is a transient field.
isTypePC() - Method in class org.apache.openjpa.meta.FieldMetaData
 
isTypePC() - Method in interface org.apache.openjpa.meta.ValueMetaData
Whether the type is a persistence capable instance.
isTypePC() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
isUnion() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
isUnion() - Method in interface org.apache.openjpa.jdbc.sql.Union
Whether this is a true UNION, rather than a logical combination of independent selects.
isUnique(ForeignKey) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Return whether the given foreign key is unique.
isUnique() - Method in class org.apache.openjpa.jdbc.schema.Index
Return true if this is a UNIQUE index.
isUnique() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
isUnique() - Method in interface org.apache.openjpa.kernel.QueryContext
The unique flag.
isUnique() - Method in class org.apache.openjpa.kernel.QueryImpl
 
isUpdatable(int, boolean) - Method in class org.apache.openjpa.jdbc.schema.ColumnIO
Whether the column at the given index is updatable in this context.
isUpdatable(Column, boolean) - Method in class org.apache.openjpa.jdbc.schema.ColumnIO
Equivalent to isUpdatable (0, nullValue), but returns false if the given column is null.
isUserDefined(Class) - Static method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
Helper method; returns true if the given class appears to be user-defined.
isValid() - Method in interface org.apache.openjpa.jdbc.sql.Row
Whether this row has information set on it.
isValid() - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
isValidating() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Whether this is a validating parser.
isVariable() - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
 
isVariable() - Method in class org.apache.openjpa.kernel.exps.Val
 
isVariable() - Method in interface org.apache.openjpa.kernel.exps.Value
Return true if this value is a variable.
isVerbose() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
Whether this serialization is in verbose mode.
isVersion() - Method in class org.apache.openjpa.meta.FieldMetaData
Whether this field holds optimistic version information.
isVersionable() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
isVersionable() - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Return true if this field can be used as part of a state image for optimistic locking.
isVersionable() - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
isVersionable(ValueMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractValueHandler
 
isVersionable() - Method in class org.apache.openjpa.jdbc.meta.strats.EnumValueHandler
 
isVersionable() - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
isVersionable(ValueMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.ImmutableValueHandler
 
isVersionable() - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
isVersionable() - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
isVersionable(ValueMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.UntypedPCValueHandler
 
isVersionable(ValueMapping) - Method in interface org.apache.openjpa.jdbc.meta.ValueHandler
Return whether the values managed by this handler can be used in state image versioning.
isVersionCheckRequired() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
isVersionCheckRequired() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
isVersionCheckRequired() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
isVersionCheckRequired() - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Returns true if this state needs to issue a version check at flush time.
isVersionCheckRequired() - Method in class org.apache.openjpa.kernel.StateManagerImpl
Returns whether this instance needs a version check.
isVersionUpdateRequired() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
isVersionUpdateRequired() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
isVersionUpdateRequired() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
isVersionUpdateRequired() - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Returns true if this state needs to issue a version update, possibly as a result of being locked.
isVersionUpdateRequired() - Method in class org.apache.openjpa.kernel.StateManagerImpl
Returns whether this instance needs a version update.
isWaiting(Thread) - Method in class org.apache.openjpa.lib.util.concurrent.WaitQueue
 
isWarnEnabled() - Method in class org.apache.openjpa.lib.log.AbstractLog
 
isWarnEnabled() - Method in class org.apache.openjpa.lib.log.CommonsLogFactory.LogAdapter
 
isWarnEnabled() - Method in interface org.apache.openjpa.lib.log.Log
Returns if the Log.WARN log level is enabled.
isWarnEnabled() - Method in class org.apache.openjpa.lib.log.Log4JLogFactory.LogAdapter
 
isWarnEnabled() - Method in class org.apache.openjpa.lib.log.NoneLogFactory.NoneLog
 
iterator() - Method in class org.apache.openjpa.kernel.DelegatingExtent
 
iterator() - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
iterator() - Method in interface org.apache.openjpa.kernel.Extent
Return an iterator over the extent members.
iterator() - Method in class org.apache.openjpa.kernel.ExtentImpl
 
iterator() - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
iterator() - Method in class org.apache.openjpa.lib.rop.AbstractNonSequentialResultList
 
iterator() - Method in class org.apache.openjpa.lib.rop.AbstractSequentialResultList
 
iterator() - Method in class org.apache.openjpa.lib.rop.ListResultList
 
iterator() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashSet
 
iterator() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentLinkedQueue
Returns an iterator over the elements in this queue in proper sequence.
iterator() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashSet
 
iterator() - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
iterator() - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArraySet
Returns an iterator over the elements contained in this set in the order in which these elements were added.
iterator() - Method in class org.apache.openjpa.lib.util.ReferenceHashSet
 
iterator() - Method in class org.apache.openjpa.persistence.ExtentImpl
 
iterator() - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
iterator(ProxyCollection, Iterator) - Static method in class org.apache.openjpa.util.Proxies
Return an iterator that dirties its owner on calls to remove.
iterator() - Method in class org.apache.openjpa.util.ProxyArrayList
 
iterator() - Method in class org.apache.openjpa.util.ProxyHashSet
 
iterator() - Method in class org.apache.openjpa.util.ProxyLinkedList
 
iterator() - Method in class org.apache.openjpa.util.ProxyTreeSet
 
iterator() - Method in class org.apache.openjpa.util.ProxyVector
 
itr() - Method in class org.apache.openjpa.jdbc.meta.strats.LRSProxyCollection
 
itr(int) - Method in class org.apache.openjpa.lib.rop.AbstractSequentialResultList
Implement this method and List.size().
itr(int) - Method in class org.apache.openjpa.lib.rop.LazyForwardResultList
 
itr() - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
Implement this method to return an iterator over the contents of the collection.
itr() - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
Implement this method to return an iterator over the entries in the map.
IV_DUPLICATE_OID - Static variable in exception org.apache.openjpa.util.ReferentialIntegrityException
 
IV_MIXED - Static variable in exception org.apache.openjpa.util.ReferentialIntegrityException
 
IV_REFERENCE - Static variable in exception org.apache.openjpa.util.ReferentialIntegrityException
 
IV_UNIQUE - Static variable in exception org.apache.openjpa.util.ReferentialIntegrityException
 
IV_UNKNOWN - Static variable in exception org.apache.openjpa.util.ReferentialIntegrityException
 

J

javaObjectTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
JavaSQLTypes - Class in org.apache.openjpa.jdbc.meta
Java SQL type constants.
JavaSQLTypes() - Constructor for class org.apache.openjpa.jdbc.meta.JavaSQLTypes
 
JavaTypes - Class in org.apache.openjpa.meta
Type constants for managed fields.
JavaTypes() - Constructor for class org.apache.openjpa.meta.JavaTypes
 
JavaVersions - Class in org.apache.openjpa.lib.util
Utilities for dealing with different Java spec versions.
JavaVersions() - Constructor for class org.apache.openjpa.lib.util.JavaVersions
 
JDataStoreDictionary - Class in org.apache.openjpa.jdbc.sql
Dictionary for Borland JDataStore
JDataStoreDictionary() - Constructor for class org.apache.openjpa.jdbc.sql.JDataStoreDictionary
 
JDBC3SavepointManager - Class in org.apache.openjpa.jdbc.kernel
SavepointManager implementation that uses JDBC 3 savepoints to store state.
JDBC3SavepointManager() - Constructor for class org.apache.openjpa.jdbc.kernel.JDBC3SavepointManager
 
JDBC_DEFAULT - Static variable in class org.apache.openjpa.jdbc.meta.JavaSQLTypes
 
JDBCAggregateListener - Interface in org.apache.openjpa.jdbc.kernel.exps
JDBC extension to the AggregateListener.
JDBCBrokerFactory - Class in org.apache.openjpa.jdbc.kernel
BrokerFactory type for use with the JDBC runtime.
JDBCBrokerFactory(JDBCConfiguration) - Constructor for class org.apache.openjpa.jdbc.kernel.JDBCBrokerFactory
Construct the factory with the given option settings; however, the factory construction methods are recommended.
JDBCConfiguration - Interface in org.apache.openjpa.jdbc.conf
Configuration that defines the properties necessary to configure runtime and connect to a JDBC DataSource.
JDBCConfigurationImpl - Class in org.apache.openjpa.jdbc.conf
Default implementation of the JDBCConfiguration interface.
JDBCConfigurationImpl() - Constructor for class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
Default constructor.
JDBCConfigurationImpl(boolean) - Constructor for class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
Constructor.
JDBCConfigurationImpl(boolean, boolean) - Constructor for class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
Constructor.
JDBCConfigurationImpl(JDBCConfiguration) - Constructor for class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
Copy constructor
JDBCEvent - Class in org.apache.openjpa.lib.jdbc
A JDBC event.
JDBCEvent(Connection, short, JDBCEvent, Statement, String) - Constructor for class org.apache.openjpa.lib.jdbc.JDBCEvent
Constructor.
JDBCEventConnectionDecorator - Class in org.apache.openjpa.lib.jdbc
Manages the firing of JDBCEvents.
JDBCEventConnectionDecorator() - Constructor for class org.apache.openjpa.lib.jdbc.JDBCEventConnectionDecorator
 
JDBCExpressionFactory - Class in org.apache.openjpa.jdbc.kernel.exps
Expression factory implementation that can be used to execute queries via SQL.
JDBCExpressionFactory(ClassMapping) - Constructor for class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
Constructor.
JDBCFetchConfiguration - Interface in org.apache.openjpa.jdbc.kernel
JDBC extensions to OpenJPA's FetchConfiguration.
JDBCFetchConfigurationImpl - Class in org.apache.openjpa.jdbc.kernel
JDBC extensions to OpenJPA's FetchConfiguration.
JDBCFetchConfigurationImpl() - Constructor for class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
JDBCFetchPlan - Interface in org.apache.openjpa.persistence.jdbc
JDBC extensions to the fetch plan.
JDBCFetchPlanImpl - Class in org.apache.openjpa.persistence.jdbc
JDBC extensions to the fetch plan.
JDBCFetchPlanImpl(FetchConfiguration) - Constructor for class org.apache.openjpa.persistence.jdbc.JDBCFetchPlanImpl
Constructor; supply delegate.
JDBCFilterListener - Interface in org.apache.openjpa.jdbc.kernel.exps
JDBC extension to the FilterListener.
JDBCListener - Interface in org.apache.openjpa.lib.jdbc
A listener for all JDBCEvents that occur.
jdbcListenerPlugins - Variable in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
JDBCLockManager - Interface in org.apache.openjpa.jdbc.kernel
Extension of the LockManager interface with methods for datastore locking during the select and load process.
JDBCPersistenceProductDerivation - Class in org.apache.openjpa.persistence.jdbc
Sets JDBC-specific JPA specification defaults.
JDBCPersistenceProductDerivation() - Constructor for class org.apache.openjpa.persistence.jdbc.JDBCPersistenceProductDerivation
 
JDBCProductDerivation - Class in org.apache.openjpa.jdbc.conf
Sets JDBC as default store.
JDBCProductDerivation() - Constructor for class org.apache.openjpa.jdbc.conf.JDBCProductDerivation
 
JDBCSeq - Interface in org.apache.openjpa.jdbc.kernel
Specialization of the the Seq interface to provide information on the schema needed by this sequence.
JDBCSeqValue - Class in org.apache.openjpa.jdbc.conf
Adds additional aliases to base SeqValue.
JDBCSeqValue(String) - Constructor for class org.apache.openjpa.jdbc.conf.JDBCSeqValue
 
JDBCStore - Interface in org.apache.openjpa.jdbc.kernel
Represents the JDBC store.
JDBCStoreManager - Class in org.apache.openjpa.jdbc.kernel
StoreManager plugin that uses JDBC to store persistent data in a relational data store.
JDBCStoreManager() - Constructor for class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
JDBCStoreManager.RefCountConnection - Class in org.apache.openjpa.jdbc.kernel
Connection wrapper that keeps an internal ref count so that it knows when to really close.
JDBCStoreManager.RefCountConnection(Connection) - Constructor for class org.apache.openjpa.jdbc.kernel.JDBCStoreManager.RefCountConnection
 
JDBCStoreQuery - Class in org.apache.openjpa.jdbc.kernel
JDBC query implementation.
JDBCStoreQuery(JDBCStore, ExpressionParser) - Constructor for class org.apache.openjpa.jdbc.kernel.JDBCStoreQuery
Constructor.
JDBCStringContains - Class in org.apache.openjpa.jdbc.kernel.exps
Deprecated. Use matches() instead.
JDBCStringContains() - Constructor for class org.apache.openjpa.jdbc.kernel.exps.JDBCStringContains
Deprecated.  
JDBCWildcardMatch - Class in org.apache.openjpa.jdbc.kernel.exps
Deprecated. Use matches() instead.
JDBCWildcardMatch() - Constructor for class org.apache.openjpa.jdbc.kernel.exps.JDBCWildcardMatch
Deprecated.  
JMSRemoteCommitProvider - Class in org.apache.openjpa.event
JMS-based implementation of RemoteCommitProvider that listens for object modifications and propagates those changes to other RemoteCommitProviders over a JMS topic.
JMSRemoteCommitProvider() - Constructor for class org.apache.openjpa.event.JMSRemoteCommitProvider
 
JNDIManagedRuntime - Class in org.apache.openjpa.ee
Implementation of the ManagedRuntime interface that uses JNDI to find the TransactionManager.
JNDIManagedRuntime() - Constructor for class org.apache.openjpa.ee.JNDIManagedRuntime
 
join(Select) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Return any joins needed to get from the primary table to this table.
join(Joins, boolean) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
join(Joins, boolean, boolean) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Joins from the owning class' table to the table where this field lies using the join foreign key.
join(Joins, boolean) - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Join this value to the class table.
join(Joins, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
join(Joins, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedFieldStrategy
 
join(Joins, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
join(Joins, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.MapTableFieldStrategy
 
join(Joins, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
join(Joins, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationCollectionInverseKeyFieldStrategy
 
join(Joins, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationCollectionTableFieldStrategy
 
join(Joins, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
join(Joins, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyInverseKeyFieldStrategy
 
join(Joins, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyInverseKeyFieldStrategy
 
join(Joins, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyTableFieldStrategy
 
join(Joins, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyTableFieldStrategy
 
join(Joins, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.StoreCollectionFieldStrategy
Join to the owning field table for the given element mapping from ContainerFieldStrategy.getIndependentElementMappings(boolean) (or null).
join(Joins, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
join(Column, Column) - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Join a local column to a primary key column of another table.
Join - Class in org.apache.openjpa.jdbc.sql
Represents a SQL join.
join(ForeignKey, boolean, boolean) - Method in interface org.apache.openjpa.jdbc.sql.Joins
Join the columns of the given foreign key.
join(ForeignKey, boolean, boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
join(ForeignKey, boolean, boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
JOIN_EXPECTED_INVERSE - Static variable in interface org.apache.openjpa.jdbc.meta.ValueMapping
Inverse join that is marked up as a forward join because the backing mapping expects an inverse direction.
JOIN_FORWARD - Static variable in class org.apache.openjpa.jdbc.meta.MappingInfo
 
JOIN_FORWARD - Static variable in interface org.apache.openjpa.jdbc.meta.ValueMapping
Standard forward join.
JOIN_INVERSE - Static variable in class org.apache.openjpa.jdbc.meta.MappingInfo
 
JOIN_INVERSE - Static variable in interface org.apache.openjpa.jdbc.meta.ValueMapping
Inverse join.
JOIN_NONE - Static variable in class org.apache.openjpa.jdbc.meta.MappingInfo
 
JOIN_REL - Static variable in interface org.apache.openjpa.jdbc.kernel.exps.Val
Initialization flag indicating to join into any relation path.
Joinable - Interface in org.apache.openjpa.jdbc.meta
Represents a value that can be joined to.
joinConstant(Object, Column) - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Join a constant value to a primary key column of another table.
joinConstant(Column, Object) - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Join a constant value to a local column of this table.
joinCount() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
joinCount() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
joinElementRelation(Joins, ClassMapping) - Method in interface org.apache.openjpa.jdbc.meta.strats.LRSCollectionFieldStrategy
Join this value's table to the table for the given element mapping from LRSCollectionFieldStrategy.getIndependentElementMappings(boolean) (or null).
joinElementRelation(Joins, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationCollectionInverseKeyFieldStrategy
 
joinElementRelation(Joins, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationCollectionTableFieldStrategy
 
joinElementRelation(Joins, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyInverseKeyFieldStrategy
 
joinElementRelation(Joins, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyTableFieldStrategy
 
joinElementRelation(Joins, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.StoreCollectionFieldStrategy
Join this value's table to the table for the given element mapping from ContainerFieldStrategy.getIndependentElementMappings(boolean) (or null).
joinKey(Joins, boolean) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
joinKey(Joins, boolean) - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Join the key value to the class table.
joinKey(Joins, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
joinKey(Joins, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.MapTableFieldStrategy
 
joinKey(Joins, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapInverseKeyFieldStrategy
 
joinKey(Joins, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapTableFieldStrategy
 
joinKeyRelation(Joins, boolean, boolean) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
joinKeyRelation(Joins, boolean, boolean) - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Join this value's table to the table for the related first class object key type, if any.
joinKeyRelation(Joins, boolean, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
joinKeyRelation(Joins, ClassMapping) - Method in interface org.apache.openjpa.jdbc.meta.strats.LRSMapFieldStrategy
Join this value's table to the table for the given key mapping from LRSMapFieldStrategy.getIndependentKeyMappings(boolean) (or null).
joinKeyRelation(Joins, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.MapTableFieldStrategy
Invokes FieldStrategy.joinKeyRelation(org.apache.openjpa.jdbc.sql.Joins, boolean, boolean) by default.
joinKeyRelation(Joins, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapInverseKeyFieldStrategy
 
joinKeyRelation(Joins, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapTableFieldStrategy
 
joinRelation(Joins, boolean, boolean) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
joinRelation(Joins, boolean, boolean) - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Join this value's table to the table for the related first class object type, if any.
joinRelation(Joins, boolean, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
joinRelation(Joins, boolean, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
joinRelation(Joins, boolean, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
joinRelation(Joins, boolean, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyTableFieldStrategy
 
joinRelation(String, ForeignKey, ClassMapping, int, boolean, boolean) - Method in interface org.apache.openjpa.jdbc.sql.Joins
Join the columns of the given foreign key, which represents a relation via the given field name.
joinRelation(String, ForeignKey, ClassMapping, int, boolean, boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
joinRelation(String, ForeignKey, ClassMapping, int, boolean, boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
joins - Variable in class org.apache.openjpa.jdbc.kernel.exps.ExpState
 
Joins - Interface in org.apache.openjpa.jdbc.sql
Tracks joins made when traversing relations in a select.
joins() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
joins() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
joinSuperclass(Joins, boolean) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
joinSuperclass(Joins, boolean) - Method in interface org.apache.openjpa.jdbc.meta.ClassStrategy
Join the mapping and its superclass.
joinSuperclass(Joins, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractClassStrategy
 
joinSuperclass(Joins, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.VerticalClassStrategy
 
joinSyntax - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
JoinSyntaxes - Interface in org.apache.openjpa.jdbc.sql
Constants for ways of describing joins in SQL.
joinTransaction() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
joinValueRelation(Joins, ClassMapping) - Method in interface org.apache.openjpa.jdbc.meta.strats.LRSMapFieldStrategy
Join this value's table to the table for the given value mapping from LRSMapFieldStrategy.getIndependentValueMappings(boolean) (or null).
joinValueRelation(Joins, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.MapTableFieldStrategy
Invokes FieldStrategy.joinRelation(org.apache.openjpa.jdbc.sql.Joins, boolean, boolean) by default.
joinValueRelation(Joins, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapInverseKeyFieldStrategy
 
joinValueRelation(Joins, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapTableFieldStrategy
 
JPQLParser - Class in org.apache.openjpa.kernel.jpql
Parser for JPQL queries.
JPQLParser() - Constructor for class org.apache.openjpa.kernel.jpql.JPQLParser
 

K

KEY - Static variable in class org.apache.openjpa.conf.BrokerFactoryValue
 
KEY - Static variable in class org.apache.openjpa.persistence.EntityManagerFactoryValue
Configuration property key.
KEY_PROVIDER - Static variable in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
KeyDependent - Annotation Type in org.apache.openjpa.persistence
Dependent map key marker.
keyExpired(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
 
keyExpired(Object) - Method in class org.apache.openjpa.lib.util.ReferenceHashMap
 
keyExpired(Object) - Method in interface org.apache.openjpa.lib.util.ReferenceMap
Overridable callback for when a key reference expires.
keyRemoved(Object, boolean) - Method in class org.apache.openjpa.datacache.AbstractDataCache
Invoke when a key is removed from this cache.
keys(Object) - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
Return all keys for the given value.
keySet() - Method in class org.apache.openjpa.datacache.AbstractQueryCache
Return a threadsafe view of the keys in this cache.
keySet() - Method in class org.apache.openjpa.datacache.ConcurrentQueryCache
 
keySet() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
Returns a set view of the keys contained in this map.
keySet() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
Returns a Set view of the keys contained in this HashMap.
keySet() - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
keySet() - Method in class org.apache.openjpa.util.CacheMap
 
keySet() - Method in class org.apache.openjpa.util.ProxyHashMap
 
keySet() - Method in class org.apache.openjpa.util.ProxyHashtable
 
keySet() - Method in class org.apache.openjpa.util.ProxyProperties
 
keySet() - Method in class org.apache.openjpa.util.ProxyTreeMap
 
KeyType - Annotation Type in org.apache.openjpa.persistence
Indicates the persistent key type of a map field, if different than the declared type.

L

LANG_JPQL - Static variable in class org.apache.openjpa.kernel.jpql.JPQLParser
 
LANG_METHODQL - Static variable in class org.apache.openjpa.kernel.QueryLanguages
 
LANG_SQL - Static variable in class org.apache.openjpa.kernel.QueryLanguages
 
LANGUAGE - Static variable in class org.apache.openjpa.kernel.MethodStoreQuery
 
last() - Method in interface org.apache.openjpa.kernel.exps.Path
Return the last field in the path, or null if the path does not not contain a final field.
last() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
lastGeneratedKeyQuery - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
lastIndexOf(Object) - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
lastIndexOf(Object) - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
lastIndexOf(Object) - Method in class org.apache.openjpa.lib.rop.AbstractNonSequentialResultList
 
lastIndexOf(Object) - Method in class org.apache.openjpa.lib.rop.AbstractSequentialResultList
 
lastIndexOf(Object) - Method in class org.apache.openjpa.lib.rop.ListResultList
 
lastIndexOf(Object) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
lastIndexOf(Object, int) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
LazyForwardResultList - Class in org.apache.openjpa.lib.rop
Lazy forward-only result list.
LazyForwardResultList(ResultObjectProvider) - Constructor for class org.apache.openjpa.lib.rop.LazyForwardResultList
 
LazySchemaFactory - Class in org.apache.openjpa.jdbc.schema
Factory that uses database metadata to construct the system schema.
LazySchemaFactory() - Constructor for class org.apache.openjpa.jdbc.schema.LazySchemaFactory
 
length(Select, ExpContext, ExpState) - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
 
length() - Method in interface org.apache.openjpa.jdbc.kernel.exps.FilterValue
Return the number of SQL elements in this value.
length(Select, ExpContext, ExpState) - Method in interface org.apache.openjpa.jdbc.kernel.exps.Val
Return the number of SQL elements in this value.
length() - Method in class org.apache.openjpa.lib.util.CodeFormat
Return the length of the internal buffer.
lessThan(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
lessThan(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return an expression representing the given condition.
lessThan(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
lessThanEqual(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
lessThanEqual(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return an expression representing the given condition.
lessThanEqual(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
LEVEL_CLASS - Static variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
 
LEVEL_PACKAGE - Static variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
 
LifecycleCallbacks - Interface in org.apache.openjpa.event
A lifecycle listener that responds to callbacks rather than events.
LifecycleEvent - Class in org.apache.openjpa.event
Lifecycle event on a persistent instance.
LifecycleEvent(Object, int) - Constructor for class org.apache.openjpa.event.LifecycleEvent
Constructor.
LifecycleEvent(Object, Object, int) - Constructor for class org.apache.openjpa.event.LifecycleEvent
Constructor.
LifecycleEventManager - Class in org.apache.openjpa.event
Manager that can be used to track and notify listeners on lifecycle events.
LifecycleEventManager() - Constructor for class org.apache.openjpa.event.LifecycleEventManager
 
LifecycleEventManager.ListenerAdapter - Interface in org.apache.openjpa.event
Interface that facades to other lifecycle listener interfaces can implement to choose which events to respond to based on their delegate.
LifecycleEventManager.ListenerList - Class in org.apache.openjpa.event
Extended list that tracks what event types its elements care about.
LifecycleEventManager.ListenerList(int) - Constructor for class org.apache.openjpa.event.LifecycleEventManager.ListenerList
 
LifecycleEventManager.ListenerList(LifecycleEventManager.ListenerList) - Constructor for class org.apache.openjpa.event.LifecycleEventManager.ListenerList
 
LifecycleListener - Interface in org.apache.openjpa.event
Interface for listening to all LifecycleEvents.
LifecycleMetaData - Class in org.apache.openjpa.meta
Information about lifecycle events for a managed type.
list() - Method in class org.apache.openjpa.kernel.DelegatingExtent
 
list() - Method in interface org.apache.openjpa.kernel.Extent
Returns a list of all objects represented by this extent.
list() - Method in class org.apache.openjpa.kernel.ExtentImpl
 
list() - Method in interface org.apache.openjpa.persistence.Extent
List the extent contents.
list() - Method in class org.apache.openjpa.persistence.ExtentImpl
 
listIterator() - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
listIterator(int) - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
listIterator() - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
listIterator(int) - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
listIterator() - Method in class org.apache.openjpa.lib.rop.AbstractNonSequentialResultList
 
listIterator(int) - Method in class org.apache.openjpa.lib.rop.AbstractNonSequentialResultList
 
listIterator() - Method in class org.apache.openjpa.lib.rop.AbstractSequentialResultList
 
listIterator(int) - Method in class org.apache.openjpa.lib.rop.AbstractSequentialResultList
 
listIterator() - Method in class org.apache.openjpa.lib.rop.ListResultList
 
listIterator(int) - Method in class org.apache.openjpa.lib.rop.ListResultList
 
listIterator() - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
listIterator(int) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
listIterator(ProxyCollection, ListIterator, Class) - Static method in class org.apache.openjpa.util.Proxies
Return a proxy iterator that dirties its owner on remove, set, and add.
listIterator() - Method in class org.apache.openjpa.util.ProxyArrayList
 
listIterator(int) - Method in class org.apache.openjpa.util.ProxyArrayList
 
listIterator() - Method in class org.apache.openjpa.util.ProxyLinkedList
 
listIterator(int) - Method in class org.apache.openjpa.util.ProxyLinkedList
 
listIterator() - Method in class org.apache.openjpa.util.ProxyVector
 
listIterator(int) - Method in class org.apache.openjpa.util.ProxyVector
 
ListResultList - Class in org.apache.openjpa.lib.rop
A basic ResultList implementation that wraps a normal list.
ListResultList(List) - Constructor for class org.apache.openjpa.lib.rop.ListResultList
Constructor.
ListResultObjectProvider - Class in org.apache.openjpa.lib.rop
A result object provider wrapped around a normal list.
ListResultObjectProvider(List) - Constructor for class org.apache.openjpa.lib.rop.ListResultObjectProvider
Constructor.
Literal - Interface in org.apache.openjpa.kernel.exps
Interface for any literal value.
load(OpenJPAStateManager, BitSet, FetchConfiguration, int, Object) - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
This method is invoked when OpenJPA needs to load additional data into an object that has already been at least partially loaded by a previous AbstractStoreManager.initialize(org.apache.openjpa.kernel.OpenJPAStateManager, org.apache.openjpa.kernel.PCState, org.apache.openjpa.kernel.FetchConfiguration, java.lang.Object) invocation.
load(OpenJPAStateManager, BitSet, FetchConfiguration, int, Object) - Method in class org.apache.openjpa.datacache.DataCacheStoreManager
 
load(ExpContext, ExpState, Result) - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
 
load(ExpContext, ExpState, Result) - Method in interface org.apache.openjpa.jdbc.kernel.exps.Val
Load the data for this value.
load(OpenJPAStateManager, BitSet, FetchConfiguration, int, Object) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
load(ClassMapping, JDBCFetchConfiguration, BitSet, Result) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
Load the object in the current row of the given result.
load(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
load(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
load(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result) - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Load virtual row data; the given result is not guaranteed to contain data for this field, so the field mapping should make sure the result contains its needed column data before loading.
load(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration) - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Load secondary data using a connection from the store manager.
load(Class, int, ClassLoader) - Method in class org.apache.openjpa.jdbc.meta.MetaDataPlusMappingFactory
 
load(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
load(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
load(OpenJPAStateManager, JDBCStore, Result) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractVersionStrategy
 
load(OpenJPAStateManager, JDBCStore, Result) - Method in class org.apache.openjpa.jdbc.meta.strats.ColumnVersionStrategy
 
load(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedFieldStrategy
 
load(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result) - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
load(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
load(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.MapTableFieldStrategy
 
load(Column, Result, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedByteArrayFieldStrategy
 
load(Column, Result, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedCharArrayFieldStrategy
 
load(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result) - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
load(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
load(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
load(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.StoreCollectionFieldStrategy
 
load(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result) - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
load(OpenJPAStateManager, JDBCStore, Result) - Method in class org.apache.openjpa.jdbc.meta.Version
 
load(OpenJPAStateManager, JDBCStore, Result) - Method in interface org.apache.openjpa.jdbc.meta.VersionStrategy
Load data.
load(ClassMapping, JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
load(ClassMapping, JDBCStore, JDBCFetchConfiguration, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
load(ClassMapping, JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
load(ClassMapping, JDBCStore, JDBCFetchConfiguration, Joins) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
load(ClassMapping, JDBCStore, JDBCFetchConfiguration) - Method in interface org.apache.openjpa.jdbc.sql.Result
Load a pc object using the given store manager.
load(ClassMapping, JDBCStore, JDBCFetchConfiguration, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Result
Load a pc object using the given store manager.
load(ClassMapping, JDBCStore, JDBCFetchConfiguration, Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
load(OpenJPAStateManager, FetchConfiguration) - Method in class org.apache.openjpa.kernel.AbstractPCResultObjectProvider
Load data from the current input record into the given state manager.
load(OpenJPAStateManager, BitSet, FetchConfiguration, int, Object) - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
load(FetchConfiguration) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
load(FetchConfiguration) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
load(FetchConfiguration) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
load(FetchConfiguration) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Load fetch group fields.
load(OpenJPAStateManager, FetchConfiguration, Object) - Method in interface org.apache.openjpa.kernel.PCData
Loads all fields that are currently stored in the cache into the given state manager.
load(OpenJPAStateManager, BitSet, FetchConfiguration, Object) - Method in interface org.apache.openjpa.kernel.PCData
Loads some or all of the marked fields from the cache into the given state manager.
load(OpenJPAStateManager, FetchConfiguration, Object) - Method in class org.apache.openjpa.kernel.PCDataImpl
 
load(OpenJPAStateManager, BitSet, FetchConfiguration, Object) - Method in class org.apache.openjpa.kernel.PCDataImpl
 
load(FetchConfiguration) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
load(FetchConfiguration, int, BitSet, Object, boolean) - Method in class org.apache.openjpa.kernel.StateManagerImpl
Load the state of this instance based on the given fetch configuration and load mode.
load(OpenJPAStateManager, BitSet, FetchConfiguration, int, Object) - Method in interface org.apache.openjpa.kernel.StoreManager
Load the given state manager.
load(String, String, ClassLoader) - Method in class org.apache.openjpa.lib.conf.AbstractProductDerivation
 
load(File, String) - Method in class org.apache.openjpa.lib.conf.AbstractProductDerivation
 
load(String, String, ClassLoader) - Method in interface org.apache.openjpa.lib.conf.ProductDerivation
Load the given given resource into the returned ConfigurationProvider, or return null if it is not a resource this receiver understands.
load(File, String) - Method in interface org.apache.openjpa.lib.conf.ProductDerivation
Load given file, or return null if it is not a file this receiver understands.
load(String, String, ClassLoader) - Static method in class org.apache.openjpa.lib.conf.ProductDerivations
Load the given given resource, or return false if it is not a resource this provider understands.
load(File, String, ClassLoader) - Static method in class org.apache.openjpa.lib.conf.ProductDerivations
Load given file, or return false if it is not a file this provider understands.
load(InputStream) - Method in class org.apache.openjpa.lib.util.FormatPreservingProperties
Loads the properties in in, according to the rules described in Properties.load(java.io.InputStream).
load(Class, int, ClassLoader) - Method in class org.apache.openjpa.meta.DelegatingMetaDataFactory
 
load(Class, int, ClassLoader) - Method in interface org.apache.openjpa.meta.MetaDataFactory
Load metadata for the given class in the given mode(s).
load(Class, int, ClassLoader) - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
load(Class, int, ClassLoader) - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
 
load(PersistenceUnitInfo, Map) - Method in class org.apache.openjpa.persistence.PersistenceProductDerivation
Load configuration from the given persistence unit with the specified user properties.
load(String, String, Map) - Method in class org.apache.openjpa.persistence.PersistenceProductDerivation
Load configuration from the given resource and unit names, which may be null.
load(String, String, ClassLoader) - Method in class org.apache.openjpa.persistence.PersistenceProductDerivation
 
load(File, String) - Method in class org.apache.openjpa.persistence.PersistenceProductDerivation
 
load(InputStream) - Method in class org.apache.openjpa.util.ProxyProperties
 
load(OpenJPAStateManager, FetchConfiguration) - Method in class org.apache.openjpa.xmlstore.ObjectData
Load the data and version information for this object into the given state manager.
load(OpenJPAStateManager, BitSet, FetchConfiguration) - Method in class org.apache.openjpa.xmlstore.ObjectData
Load the data and version information for this object into the given state manager.
load(ClassMetaData) - Method in class org.apache.openjpa.xmlstore.XMLFileHandler
Loads all instances of meta into a list of objects.
load(OpenJPAStateManager, BitSet, FetchConfiguration, int, Object) - Method in class org.apache.openjpa.xmlstore.XMLStoreManager
 
LOAD_ALL - Static variable in class org.apache.openjpa.kernel.StateManagerImpl
 
LOAD_FGS - Static variable in class org.apache.openjpa.kernel.StateManagerImpl
 
LOAD_REQUIRED - Static variable in interface org.apache.openjpa.enhance.PersistenceCapable
 
LOAD_SERIALIZE - Static variable in class org.apache.openjpa.kernel.StateManagerImpl
 
loadAll(Collection, PCState, int, FetchConfiguration, Object) - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
This implementation just delegates to the proper singular method (StoreManager.initialize(org.apache.openjpa.kernel.OpenJPAStateManager, org.apache.openjpa.kernel.PCState, org.apache.openjpa.kernel.FetchConfiguration, java.lang.Object) or StoreManager.load(org.apache.openjpa.kernel.OpenJPAStateManager, java.util.BitSet, org.apache.openjpa.kernel.FetchConfiguration, int, java.lang.Object)) depending on each state manager's state.
loadAll(Collection, PCState, int, FetchConfiguration, Object) - Method in class org.apache.openjpa.datacache.DataCacheStoreManager
 
loadAll(Collection, PCState, int, FetchConfiguration, Object) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
loadAll(Collection, PCState, int, FetchConfiguration, Object) - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
loadAll(Collection, PCState, int, FetchConfiguration, Object) - Method in interface org.apache.openjpa.kernel.StoreManager
Initialize, load, or validate the existance of all of the given objects.
loadAll(Collection, StoreManager, PCState, int, FetchConfiguration, Object) - Static method in class org.apache.openjpa.util.ImplHelper
Helper for store manager implementations.
loadClass(String) - Method in class org.apache.openjpa.lib.util.TemporaryClassLoader
 
loadClass(String, boolean) - Method in class org.apache.openjpa.lib.util.TemporaryClassLoader
 
loadDataStore(ValueMapping, Result, Joins, Column[]) - Static method in class org.apache.openjpa.jdbc.meta.strats.HandlerStrategies
Load the datastore value from the given result.
loadDefaults(ClassLoader) - Method in class org.apache.openjpa.lib.conf.AbstractProductDerivation
 
loadDefaults(ClassLoader) - Method in interface org.apache.openjpa.lib.conf.ProductDerivation
Load defaults into the returned ConfigurationProvider, or return null if no defaults are found.
loadDefaults(ClassLoader) - Static method in class org.apache.openjpa.lib.conf.ProductDerivations
Return a ConfigurationProvider that has parsed system defaults.
loadDefaults(ClassLoader) - Method in class org.apache.openjpa.persistence.PersistenceProductDerivation
 
loadEagerJoin(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
loadEagerJoin(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result) - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Load the joined eager result.
loadEagerJoin(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
loadEagerJoin(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
loadEagerJoin(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result) - Method in class org.apache.openjpa.jdbc.meta.strats.StoreCollectionFieldStrategy
 
loadEagerParallel(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Object) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
loadEagerParallel(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Object) - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Load the batched eager result.
loadEagerParallel(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
loadEagerParallel(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
loadEagerParallel(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.StoreCollectionFieldStrategy
 
loadedForUpdate(OpenJPAStateManager) - Method in interface org.apache.openjpa.jdbc.kernel.JDBCLockManager
Notification that the given instance was loaded via a result set produced by a FOR UPDATE select.
loadedForUpdate(OpenJPAStateManager) - Method in class org.apache.openjpa.jdbc.kernel.PessimisticLockManager
 
loadElement(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in interface org.apache.openjpa.jdbc.meta.strats.LRSCollectionFieldStrategy
Load an element of the collection.
loadElement(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationCollectionInverseKeyFieldStrategy
 
loadElement(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationCollectionTableFieldStrategy
 
loadElement(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyInverseKeyFieldStrategy
 
loadElement(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyTableFieldStrategy
 
loadElement(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.StoreCollectionFieldStrategy
Load an element of the collection.
loadEmbedded(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Object) - Method in interface org.apache.openjpa.jdbc.meta.Embeddable
Load this strategy's field by transforming the given datastore value.
loadEmbedded(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
loadEmbedded(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
loadEmbedded(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
loadEmbedded(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
loadFactor() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
Returns the load factor for this map.
LoadFetchGroup - Annotation Type in org.apache.openjpa.persistence
Fetch group loaded when the annotated field/property is loaded.
loadField(OpenJPAStateManager, FieldMetaData, FetchConfiguration, Object) - Method in class org.apache.openjpa.kernel.PCDataImpl
Set field-level information into the given state manager.
loadField(int, int, boolean, boolean) - Method in class org.apache.openjpa.kernel.StateManagerImpl
Load the given field's fetch group; the field itself may already be loaded if it is being set by the user.
loadGlobals(ClassLoader) - Method in class org.apache.openjpa.lib.conf.AbstractProductDerivation
 
loadGlobals() - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
Automatically load global values from the system's ProductDerivations, and from System properties.
loadGlobals(ClassLoader) - Method in interface org.apache.openjpa.lib.conf.ProductDerivation
Load globals into the returned ConfigurationProvider, or return null if no globals are found.
loadGlobals(ClassLoader) - Static method in class org.apache.openjpa.lib.conf.ProductDerivations
Return a ConfigurationProvider that has parsed system globals.
loadGlobals(ClassLoader) - Method in class org.apache.openjpa.persistence.PersistenceProductDerivation
 
loadImplData(OpenJPAStateManager) - Method in class org.apache.openjpa.kernel.PCDataImpl
Set impl data information into the given state manager.
loadImplData(OpenJPAStateManager, FieldMetaData) - Method in class org.apache.openjpa.kernel.PCDataImpl
Set field-level impl data into the given state manager.
loadIntermediate(OpenJPAStateManager, FieldMetaData) - Method in class org.apache.openjpa.kernel.PCDataImpl
Set intermediate information for the given field into the state manager.
loadKey(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in interface org.apache.openjpa.jdbc.meta.strats.LRSMapFieldStrategy
Load a key from the given result.
loadKey(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapInverseKeyFieldStrategy
 
loadKey(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapTableFieldStrategy
 
loadKeyProjection(JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
loadKeyProjection(JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Load this field's key value using the given result.
loadKeyProjection(JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
loadKeyProjection(JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.MapTableFieldStrategy
 
LoadListener - Interface in org.apache.openjpa.event
Listener for when state is loaded into a persistent instnace.
loadObject(ValueMapping, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result, Joins, Column[], boolean) - Static method in class org.apache.openjpa.jdbc.meta.strats.HandlerStrategies
Load the Object value from the given result.
loadPersistentTypes(boolean, ClassLoader) - Method in class org.apache.openjpa.meta.MetaDataRepository
Load the persistent classes named in configuration.
loadProjection(JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
loadProjection(JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Load this field value using the given result.
loadProjection(JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
loadProjection(JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedFieldStrategy
 
loadProjection(JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
loadProjection(JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.MapTableFieldStrategy
 
loadProjection(JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
loadProjection(JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.StoreCollectionFieldStrategy
 
loadProjection(JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
loadSubclasses(ClassMapping) - Method in interface org.apache.openjpa.jdbc.kernel.JDBCStore
Makes sure all subclasses of the given type are loaded in the JVM.
loadSubclasses(ClassMapping) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
Makes sure all subclasses of the given type are loaded in the JVM.
loadSubclasses(JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
 
loadSubclasses(JDBCStore) - Method in interface org.apache.openjpa.jdbc.meta.DiscriminatorStrategy
Load all subclasses of the owning class mapping into the JVM.
loadSubclasses(JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractDiscriminatorStrategy
By default, logs a warning that this discriminator cannot calculate its list of subclasses on its own.
loadSubclasses(JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.ClassNameDiscriminatorStrategy
 
loadSubclasses(JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.SuperclassDiscriminatorStrategy
 
loadValue(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in interface org.apache.openjpa.jdbc.meta.strats.LRSMapFieldStrategy
Load a value from the given result.
loadValue(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapInverseKeyFieldStrategy
 
loadValue(OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Result, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapTableFieldStrategy
 
loadVersion(OpenJPAStateManager) - Method in class org.apache.openjpa.kernel.PCDataImpl
Set version information into the given state manager.
LocalConstraint - Class in org.apache.openjpa.jdbc.schema
Constraint over local table columns, as opposed to a foreign key which spans tables.
LocalConstraint() - Constructor for class org.apache.openjpa.jdbc.schema.LocalConstraint
Default constructor.
LocalConstraint(String, Table) - Constructor for class org.apache.openjpa.jdbc.schema.LocalConstraint
Constructor.
LOCALE - Static variable in class org.apache.openjpa.meta.JavaTypes
 
Localizer - Class in org.apache.openjpa.lib.util
The Localizer provides convenient access to localized strings.
Localizer.Message - Class in org.apache.openjpa.lib.util
A Message can provide a localized message via the Localizer.Message.getMessage() method call, and can also provide the original key, package, and substitution array that were used to assemble the message.
Location - Class in org.apache.openjpa.lib.xml
 
Location() - Constructor for class org.apache.openjpa.lib.xml.Location
 
Location(boolean) - Constructor for class org.apache.openjpa.lib.xml.Location
 
locatorsUpdateCopy() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
lock() - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
 
lock(Object, int, int, OpCallbacks) - Method in interface org.apache.openjpa.kernel.Broker
Ensure that the given instance is locked at the given lock level.
lock(Object, OpCallbacks) - Method in interface org.apache.openjpa.kernel.Broker
Ensure that the given instance is locked at the current lock level, as set in the FetchConfiguration for the broker.
lock() - Method in interface org.apache.openjpa.kernel.BrokerFactory
Synchronizes on an internal lock.
lock(Object, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
lock(Object, int, int, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
lock() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
lock() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
lock(Object, int, int, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
lock(Object, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
lock() - Method in class org.apache.openjpa.kernel.DelegatingBrokerFactory
 
lock() - Method in class org.apache.openjpa.kernel.DelegatingExtent
 
lock() - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
lock() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
lock() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
lock() - Method in interface org.apache.openjpa.kernel.Extent
Synchronizes on an internal lock.
lock() - Method in class org.apache.openjpa.kernel.ExtentImpl
 
lock() - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Synchronize on internal lock if multithreaded is true.
lock() - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
lock(OpenJPAStateManager, int, int, Object) - Method in interface org.apache.openjpa.kernel.LockManager
Obtain a lock on the specified object.
lock(OpenJPAStateManager, int, int, Object) - Method in class org.apache.openjpa.kernel.NoneLockManager
 
lock() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
lock() - Method in interface org.apache.openjpa.kernel.QueryContext
Synchronize on the query's internal lock.
lock() - Method in class org.apache.openjpa.kernel.QueryImpl
 
lock() - Method in class org.apache.openjpa.kernel.StateManagerImpl
Lock the state manager if the multithreaded option is set.
lock() - Method in interface org.apache.openjpa.kernel.StoreContext
Synchronizes on an internal lock if the Multithreaded flag is set to true.
lock(OpenJPAStateManager, int, int, Object) - Method in class org.apache.openjpa.kernel.VersionLockManager
Delegates to VersionLockManager.lockInternal(org.apache.openjpa.kernel.OpenJPAStateManager, int, long, java.lang.Object) after traversing to owning instance (if embedded) and assuring that the instance is persistent, is not new, and is not already locked at a higher level.
Lock - Interface in org.apache.openjpa.lib.util.concurrent
Lock implementations provide more extensive locking operations than can be obtained using synchronized methods and statements.
lock() - Method in interface org.apache.openjpa.lib.util.concurrent.Lock
Acquires the lock.
lock() - Method in class org.apache.openjpa.lib.util.concurrent.ReentrantLock
Acquires the lock.
lock(Object, LockModeType) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
lock(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
lock(Object, LockModeType, int) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
lock(Object, LockModeType, int) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Ensure that the given instance is locked at the given lock level.
lock(Object) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Ensure that the given instance is locked at the current lock level, as set in the FetchPlan for the entity manager.
LOCK - Static variable in exception org.apache.openjpa.util.StoreException
 
LOCK_DATASTORE_ONLY - Static variable in class org.apache.openjpa.jdbc.kernel.PessimisticLockManager
 
LOCK_NONE - Static variable in interface org.apache.openjpa.kernel.LockLevels
No lock.
LOCK_READ - Static variable in interface org.apache.openjpa.kernel.LockLevels
Generic read lock level.
LOCK_WRITE - Static variable in interface org.apache.openjpa.kernel.LockLevels
Generic write lock level.
lockAll(Collection, int, int, Object) - Method in class org.apache.openjpa.kernel.AbstractLockManager
Delegates to LockManager.lock(org.apache.openjpa.kernel.OpenJPAStateManager, int, int, java.lang.Object) with each element of the collection
lockAll(Collection, int, int, OpCallbacks) - Method in interface org.apache.openjpa.kernel.Broker
Ensure that the given instances are locked at the given lock level.
lockAll(Collection, OpCallbacks) - Method in interface org.apache.openjpa.kernel.Broker
Ensure that the given instances are locked at the current lock level, as set in the FetchConfiguration for the broker.
lockAll(Collection, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
lockAll(Collection, int, int, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
lockAll(Collection, int, int, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
lockAll(Collection, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
lockAll(Collection, int, int, Object) - Method in interface org.apache.openjpa.kernel.LockManager
Obtain locks on the specified objects.
lockAll(Collection) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
lockAll(Collection, LockModeType, int) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
lockAll(Object...) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
lockAll(Object[], LockModeType, int) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
lockAll(Collection, LockModeType, int) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Ensure that the given instances are locked at the given lock level.
lockAll(Collection) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Ensure that the given instances are locked at the current lock level, as set in the FetchPlan for the entity manager.
lockAll(Object[], LockModeType, int) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Ensure that the given instances are locked at the given lock level.
lockAll(Object...) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Ensure that the given instances are locked at the current lock level, as set in the FetchPlan for the entity manager.
LockException - Exception in org.apache.openjpa.util
Exception indicating that locks on one or more objects could not be acquired.
LockException(Object) - Constructor for exception org.apache.openjpa.util.LockException
 
LockException(Object, int) - Constructor for exception org.apache.openjpa.util.LockException
 
lockInternal(OpenJPAStateManager, int, int, Object) - Method in class org.apache.openjpa.jdbc.kernel.PessimisticLockManager
 
lockInternal(OpenJPAStateManager, int, long, Object) - Method in class org.apache.openjpa.kernel.VersionLockManager
Marks the instance's transactional status in accordance with the settings of VersionLockManager.getVersionCheckOnReadLock() and VersionLockManager.getVersionUpdateOnWriteLock().
lockInterruptibly() - Method in interface org.apache.openjpa.lib.util.concurrent.Lock
Acquires the lock unless the current thread is interrupted.
lockInterruptibly() - Method in class org.apache.openjpa.lib.util.concurrent.ReentrantLock
Acquires the lock unless the current thread is interrupted.
LockLevels - Interface in org.apache.openjpa.kernel
Standard object lock levels.
LockManager - Interface in org.apache.openjpa.kernel
Handles obtaining and releasing locks on objects.
lockManagerPlugin - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
lockModeEnabled - Variable in class org.apache.openjpa.jdbc.sql.InformixDictionary
If true, then we will issue a "SET LOCK MODE TO WAIT N" statement whenever we create a Connection, in order allow waiting on locks.
lockTimeout - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
lockTimeout - Variable in class org.apache.openjpa.kernel.FetchConfigurationImpl.ConfigurationState
 
lockWaitSeconds - Variable in class org.apache.openjpa.jdbc.sql.InformixDictionary
If InformixDictionary.lockModeEnabled is true, then this parameter specifies the number of seconds we will wait to obtain a lock for inserts and pessimistic locking.
log - Variable in class org.apache.openjpa.datacache.AbstractDataCache
The log to use.
log - Variable in class org.apache.openjpa.datacache.AbstractQueryCache
The log to use.
log - Variable in class org.apache.openjpa.event.AbstractRemoteCommitProvider
 
log - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
log - Variable in class org.apache.openjpa.kernel.AbstractLockManager
Runtime log to write locking messages to.
log(short, String, Throwable) - Method in class org.apache.openjpa.lib.log.AbstractLog
Send the specified log message to the handler.
Log - Interface in org.apache.openjpa.lib.log
Logging interface that is independent of other logging frameworks.
log(short, String, Throwable) - Method in class org.apache.openjpa.lib.log.LogFactoryImpl.LogImpl
 
log - Variable in class org.apache.openjpa.meta.AbstractMetaDataFactory
 
Log4JLogFactory - Class in org.apache.openjpa.lib.log
LogFactory implementation that delegates to the Log4J framework.
Log4JLogFactory() - Constructor for class org.apache.openjpa.lib.log.Log4JLogFactory
 
Log4JLogFactory.LogAdapter - Class in org.apache.openjpa.lib.log
Adapts a Log4J logger to the Log interface.
LOG_DATACACHE - Static variable in interface org.apache.openjpa.conf.OpenJPAConfiguration
Name of logger for messages from the data cache: openjpa.DataCache.
LOG_ENHANCE - Static variable in interface org.apache.openjpa.conf.OpenJPAConfiguration
Name of logger for enhancement-related messages: openjpa.Enhance.
LOG_JDBC - Static variable in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Name of the logger for JDBC-related messages: openjpa.jdbc.JDBC.
LOG_METADATA - Static variable in interface org.apache.openjpa.conf.OpenJPAConfiguration
Name of logger for metadata-related messages: openjpa.MetaData.
LOG_QUERY - Static variable in interface org.apache.openjpa.conf.OpenJPAConfiguration
Name of logger for query logging: openjpa.Query.
LOG_RUNTIME - Static variable in interface org.apache.openjpa.conf.OpenJPAConfiguration
Name of logger for messages from the runtime system: openjpa.Runtime.
LOG_SCHEMA - Static variable in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Name of the logger for schema-related messages: openjpa.jdbc.Schema.
LOG_SQL - Static variable in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Name of the logger for SQL execution messages: openjpa.jdbc.SQL.
LOG_TOOL - Static variable in interface org.apache.openjpa.conf.OpenJPAConfiguration
Name of logger for messages from the development tools: openjpa.Tool.
LogFactory - Interface in org.apache.openjpa.lib.log
Factory for log instances.
LogFactoryAdapter - Class in org.apache.openjpa.lib.log
Base type that aids in adapting an external log framework to the LogFactory.
LogFactoryAdapter() - Constructor for class org.apache.openjpa.lib.log.LogFactoryAdapter
 
LogFactoryImpl - Class in org.apache.openjpa.lib.log
Default LogFactory implementation.
LogFactoryImpl() - Constructor for class org.apache.openjpa.lib.log.LogFactoryImpl
 
LogFactoryImpl.LogImpl - Class in org.apache.openjpa.lib.log
A simple implementation of the Log interface.
LogFactoryImpl.LogImpl() - Constructor for class org.apache.openjpa.lib.log.LogFactoryImpl.LogImpl
 
logFactoryPlugin - Variable in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
LoggingConnectionDecorator - Class in org.apache.openjpa.lib.jdbc
A ConnectionDecorator that creates logging connections and ReportingSQLExceptions.
LoggingConnectionDecorator() - Constructor for class org.apache.openjpa.lib.jdbc.LoggingConnectionDecorator
 
LoggingConnectionDecorator.SQLWarningHandler - Interface in org.apache.openjpa.lib.jdbc
Interface that allows customization of what to do when SQLWarnings occur.
LogicalUnion - Class in org.apache.openjpa.jdbc.sql
A logical union made up of multiple distinct selects whose results are combined in memory.
LogicalUnion(JDBCConfiguration, int) - Constructor for class org.apache.openjpa.jdbc.sql.LogicalUnion
Constructor.
LogicalUnion(JDBCConfiguration, Select[]) - Constructor for class org.apache.openjpa.jdbc.sql.LogicalUnion
Constructor used to seed the internal selects.
LogicalUnion(JDBCConfiguration, int, Select[]) - Constructor for class org.apache.openjpa.jdbc.sql.LogicalUnion
Delegate constructor.
LogicalUnion.Selector - Interface in org.apache.openjpa.jdbc.sql
A callback used to create the selects in a SQL union.
LogicalUnion.UnionSelect - Class in org.apache.openjpa.jdbc.sql
A select that is part of a logical union.
LogicalUnion.UnionSelect(SelectImpl, int) - Constructor for class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
logJDBC(String, Connection) - Method in class org.apache.openjpa.lib.jdbc.DataSourceLogs
Log a JDBC message on behalf of the given connection.
logJDBC(String, long, Connection) - Method in class org.apache.openjpa.lib.jdbc.DataSourceLogs
Log a JDBC message on behalf of the given connection.
LogOrphanedKeyAction - Class in org.apache.openjpa.event
Log a message when an orphaned key is discovered.
LogOrphanedKeyAction() - Constructor for class org.apache.openjpa.event.LogOrphanedKeyAction
 
LogOutputStream - Class in org.apache.openjpa.lib.log
Many standard components log to OutputStreams.
LogOutputStream(Log, int) - Constructor for class org.apache.openjpa.lib.log.LogOutputStream
Constructor.
logSQL(String, Connection) - Method in class org.apache.openjpa.lib.jdbc.DataSourceLogs
Log a SQL message on behalf of the given connection.
logSQL(String, long, Connection) - Method in class org.apache.openjpa.lib.jdbc.DataSourceLogs
Log a SQL message on behalf of the given connection.
LONG - Static variable in class org.apache.openjpa.meta.JavaTypes
 
LONG_OBJ - Static variable in class org.apache.openjpa.meta.JavaTypes
 
LongId - Class in org.apache.openjpa.util
OpenJPAId subclass appropriate for long fields.
LongId(Class, Long) - Constructor for class org.apache.openjpa.util.LongId
 
LongId(Class, String) - Constructor for class org.apache.openjpa.util.LongId
 
LongId(Class, long) - Constructor for class org.apache.openjpa.util.LongId
 
LongId(Class, long, boolean) - Constructor for class org.apache.openjpa.util.LongId
 
longVarbinaryTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
longVarcharTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
lookup(String) - Static method in class org.apache.openjpa.lib.conf.Configurations
Looks up the given name in JNDI.
lrs - Variable in class org.apache.openjpa.kernel.StoreQuery.Range
 
LRS - Annotation Type in org.apache.openjpa.persistence
Large result set field marker.
LRSCollectionFieldStrategy - Interface in org.apache.openjpa.jdbc.meta.strats
Interface implemented by collection strategies so that they can support large result set collections.
LRSMapFieldStrategy - Interface in org.apache.openjpa.jdbc.meta.strats
Interface implemented by map strategies so that they can support large result set maps.
LRSProxy - Interface in org.apache.openjpa.util
Marker interface for large result set proxies.
LRSProxyCollection - Class in org.apache.openjpa.jdbc.meta.strats
Large result set collection.
LRSProxyCollection(LRSCollectionFieldStrategy, OpenJPAConfiguration) - Constructor for class org.apache.openjpa.jdbc.meta.strats.LRSProxyCollection
 
lrsSize - Variable in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
LRSSizes - Interface in org.apache.openjpa.jdbc.kernel
Ways of calculating the size of large result sets.
LRUMap - Class in org.apache.openjpa.lib.util
Extension of the commons LRUMap that can change its maximum size.
LRUMap() - Constructor for class org.apache.openjpa.lib.util.LRUMap
 
LRUMap(int) - Constructor for class org.apache.openjpa.lib.util.LRUMap
 
LRUMap(int, float) - Constructor for class org.apache.openjpa.lib.util.LRUMap
 
LRUMap(Map) - Constructor for class org.apache.openjpa.lib.util.LRUMap
 

M

main(String[]) - Static method in class org.apache.openjpa.conf.OpenJPAVersion
 
main(String[]) - Static method in class org.apache.openjpa.ee.WASManagedRuntime
 
main(String[]) - Static method in class org.apache.openjpa.enhance.ApplicationIdTool
Usage: java org.apache.openjpa.enhance.ApplicationIdTool [option]* <class name | .java file | .class file | .jdo file>+ Where the following options are recognized.
main(String[]) - Static method in class org.apache.openjpa.enhance.PCEnhancer
Usage: java org.apache.openjpa.enhance.PCEnhancer [option]* <class name | .java file | .class file | .jdo file>+ Where the following options are recognized.
main(String[]) - Static method in class org.apache.openjpa.jdbc.kernel.ClassTableJDBCSeq
Usage: java org.apache.openjpa.jdbc.kernel.ClassTableJDBCSeq [option]* -action/-a <add | drop | get | set> [class name | .java file | .class file | .jdo file] [value] Where the following options are recognized.
main(String[]) - Static method in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
Usage: java org.apache.openjpa.jdbc.schema.NativeJDBCSequence [option]* -action/-a <add | drop | get> Where the following options are recognized.
main(String[]) - Static method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
Usage: java org.apache.openjpa.jdbc.schema.TableJDBCSequence [option]* -action/-a <add | drop | get | set> [value] Where the following options are recognized.
main(String[]) - Static method in class org.apache.openjpa.jdbc.kernel.ValueTableJDBCSeq
Usage: java org.apache.openjpa.jdbc.kernel.ValueTableJDBCSeq [option]* -action/-a <add | drop | get | set> [primary key value] [value] Where the following options are recognized.
main(String[]) - Static method in class org.apache.openjpa.jdbc.meta.MappingTool
Usage: java org.apache.openjpa.jdbc.meta.MappingTool [option]* [-action/-a <refresh | add | buildSchema | drop | validate | import | export>] <class name | .java file | .class file | .jdo file>* Where the following options are recognized.
main(String[]) - Static method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Usage: java org.apache.openjpa.jdbc.meta.ReverseMappingTool [option]* <.schema file or resource>* Where the following options are recognized.
main(String[]) - Static method in class org.apache.openjpa.jdbc.schema.SchemaTool
Usage: java org.apache.openjpa.jdbc.schema.SchemaTool [option]* [-action/-a <add | retain | drop | refresh | createDB | dropDB | build | reflect | import | export>] <.schema file or resource>* Where the following options are recognized.
main(String[]) - Static method in class org.apache.openjpa.jdbc.schema.TableSchemaFactory
Usage: java org.apache.openjpa.jdbc.schema.TableSchemaFactory [option]* -action/-a <add | drop> Where the following options are recognized.
main(String[]) - Static method in class org.apache.openjpa.lib.conf.ProductDerivations
Prints product derivation information.
main(String[]) - Static method in class org.apache.openjpa.lib.jdbc.SQLFormatter
 
main(String[]) - Static method in class org.apache.openjpa.lib.util.JavaVersions
 
main(String[]) - Static method in class org.apache.openjpa.meta.MetaDataTool
Usage: java org.apache.openjpa.meta.MetaDataTool [option]* [-action/-a <add | drop>] <class name | .java file | .class file>+ Where the following options are recognized.
MAJOR_RELEASE - Static variable in class org.apache.openjpa.conf.OpenJPAVersion
 
makeCallback(Object, Object, int) - Method in class org.apache.openjpa.event.BeanLifecycleCallbacks
 
makeCallback(Object, Object, int) - Method in interface org.apache.openjpa.event.LifecycleCallbacks
Invoke the callback for the given event type on the given instance.
makeCallback(Object, Object, int) - Method in class org.apache.openjpa.event.MethodLifecycleCallbacks
 
makeNameValid(String, NameSet, int, int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Shortens the given name to the given maximum length, then checks that it is not a reserved word.
makeReadOnly() - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
Freezes the configuration of this factory.
MANAGE_NONE - Static variable in class org.apache.openjpa.meta.FieldMetaData
Constant specifying the management level of a field.
MANAGE_PERSISTENT - Static variable in class org.apache.openjpa.meta.FieldMetaData
Constant specifying the management level of a field.
MANAGE_TRANSACTIONAL - Static variable in class org.apache.openjpa.meta.FieldMetaData
Constant specifying the management level of a field.
ManagedRuntime - Interface in org.apache.openjpa.ee
This interface must be implemented by concrete plugins to application servers in order to integrate the OpenJPA runtime in a managed environment.
managedRuntimePlugin - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
map(List, Object, Joins) - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping.PCResult
Map the given request onto a result id.
map(boolean) - Method in interface org.apache.openjpa.jdbc.meta.Strategy
Map the owning mapping using this strategy.
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractStrategy
 
map(ValueMapping, String, ColumnIO, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.BlobValueHandler
 
map(ValueMapping, String, ColumnIO, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.ByteArrayValueHandler
 
map(ValueMapping, String, ColumnIO, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.CharArrayStreamValueHandler
 
map(ValueMapping, String, ColumnIO, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.CharArrayValueHandler
 
map(ValueMapping, String, ColumnIO, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.ClobValueHandler
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.ColumnVersionStrategy
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbeddedClassStrategy
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedFieldStrategy
 
map(ValueMapping, String, ColumnIO, boolean, List, List) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedValueHandler
Maps embedded value and gathers columns and arguments into given lists.
map(ValueMapping, String, ColumnIO, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.EnumValueHandler
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.FlatClassStrategy
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.FullClassStrategy
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
map(ValueMapping, String, ColumnIO, boolean) - Static method in class org.apache.openjpa.jdbc.meta.strats.HandlerStrategies
Map the given value.
map(ValueMapping, String, ColumnIO, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.ImmutableValueHandler
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.InValueDiscriminatorStrategy
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.MapTableFieldStrategy
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedBlobFieldStrategy
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedByteArrayFieldStrategy
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedCharArrayFieldStrategy
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedClobFieldStrategy
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.ObjectIdClassStrategy
 
map(ValueMapping, String, ColumnIO, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.ObjectIdValueHandler
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationCollectionInverseKeyFieldStrategy
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationCollectionTableFieldStrategy
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapInverseKeyFieldStrategy
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapTableFieldStrategy
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyInverseKeyFieldStrategy
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyTableFieldStrategy
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.SubclassJoinDiscriminatorStrategy
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.SuperclassDiscriminatorStrategy
 
map(ValueMapping, String, ColumnIO, boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.UntypedPCValueHandler
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.ValueMapDiscriminatorStrategy
 
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.VerticalClassStrategy
 
map(ValueMapping, String, ColumnIO, boolean) - Method in interface org.apache.openjpa.jdbc.meta.ValueHandler
Map the given value and return all mapped columns, or simply return an array of unmapped default columns.
map(boolean) - Method in class org.apache.openjpa.jdbc.meta.Version
 
MAP - Static variable in class org.apache.openjpa.meta.JavaTypes
 
MapChangeTracker - Interface in org.apache.openjpa.util
Change tracker that can be used for maps.
MapChangeTrackerImpl - Class in org.apache.openjpa.util
Default MapChangeTracker.
MapChangeTrackerImpl(Map, OpenJPAConfiguration) - Constructor for class org.apache.openjpa.util.MapChangeTrackerImpl
Constructor; supply delegate map.
MapConfigurationProvider - Class in org.apache.openjpa.lib.conf
Simple configuration provider that sets configuration based on a provided map.
MapConfigurationProvider() - Constructor for class org.apache.openjpa.lib.conf.MapConfigurationProvider
Construct with null properties.
MapConfigurationProvider(Map) - Constructor for class org.apache.openjpa.lib.conf.MapConfigurationProvider
Constructor; supply properties map.
mapConstraints(String, boolean) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
mapConstraints(String, boolean) - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
Map indexes and constraints for this value, using the current ValueMappingInfo.
mapConstraints(String, boolean) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
mapJoin(boolean, boolean) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Map this field to its table, optionally requiring that it be in another table.
MAPPED_BY_PK - Static variable in interface org.apache.openjpa.meta.ValueMetaData
Marker to set on ValueMetaData.setValueMappedBy(java.lang.String) to denote that the map key is mapped by the primary key field of the value.
mapPersistentTypeNames(Object, String[]) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Implement this method to map metadata resources to the persistent types contained within them.
mapPersistentTypeNames(Object, String[]) - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
 
mapping - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
mapping - Variable in class org.apache.openjpa.jdbc.kernel.ConnectionInfo
 
MappingDefaults - Interface in org.apache.openjpa.jdbc.meta
Generates default names for tables, columns, indexes, constraints, etc.
MappingDefaultsImpl - Class in org.apache.openjpa.jdbc.meta
Default implementation of MappingDefaults.
MappingDefaultsImpl() - Constructor for class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
mappingDefaultsPlugin - Variable in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
mappingFactoryPlugin - Variable in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
MappingFactoryValue - Class in org.apache.openjpa.jdbc.conf
Handles the complex logic of creating a MetaDataFactory for combined metadata and mapping.
MappingFactoryValue(String) - Constructor for class org.apache.openjpa.jdbc.conf.MappingFactoryValue
 
MappingInfo - Class in org.apache.openjpa.jdbc.meta
Base class storing raw mapping information; defines utility methods for converting raw mapping information to full mapping to the schema.
MappingInfo() - Constructor for class org.apache.openjpa.jdbc.meta.MappingInfo
 
MappingInfo.ForeignKeyDefaults - Interface in org.apache.openjpa.jdbc.meta
Supplies default foreign key information.
MappingInfo.TableDefaults - Interface in org.apache.openjpa.jdbc.meta
Supplies default table information.
MappingOverride - Annotation Type in org.apache.openjpa.persistence.jdbc
Allows override of complex embedded or superclass mappings.
MappingOverrides - Annotation Type in org.apache.openjpa.persistence.jdbc
Allows override of complex embedded or superclass mappings.
MappingRepository - Class in org.apache.openjpa.jdbc.meta
Repository of object/relational mapping information.
MappingRepository() - Constructor for class org.apache.openjpa.jdbc.meta.MappingRepository
Default constructor.
MappingRepositoryValue - Class in org.apache.openjpa.jdbc.conf
Handles the complex logic of creating a MappingRepository for a given configuration.
MappingRepositoryValue(String) - Constructor for class org.apache.openjpa.jdbc.conf.MappingRepositoryValue
 
mappings - Variable in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
MappingStrategyInstaller - Class in org.apache.openjpa.jdbc.meta
Installer used during mapping that attempts to use the given mapping information (if any), and fails if it does not work.
MappingStrategyInstaller(MappingRepository) - Constructor for class org.apache.openjpa.jdbc.meta.MappingStrategyInstaller
Constructor; supply configuration.
MappingTool - Class in org.apache.openjpa.jdbc.meta
Tool for manipulating class mappings and associated schema.
MappingTool(JDBCConfiguration, String, boolean) - Constructor for class org.apache.openjpa.jdbc.meta.MappingTool
Constructor.
MappingTool.Flags - Class in org.apache.openjpa.jdbc.meta
Run flags.
MappingTool.Flags() - Constructor for class org.apache.openjpa.jdbc.meta.MappingTool.Flags
 
MappingTool.ImportExport - Interface in org.apache.openjpa.jdbc.meta
Helper used to import and export mapping data.
MappingToolTask - Class in org.apache.openjpa.jdbc.ant
Executes the MappingTool on the specified files.
MappingToolTask() - Constructor for class org.apache.openjpa.jdbc.ant.MappingToolTask
 
MappingToolTask.Action - Class in org.apache.openjpa.jdbc.ant
 
MappingToolTask.Action() - Constructor for class org.apache.openjpa.jdbc.ant.MappingToolTask.Action
 
MappingToolTask.SchemaAction - Class in org.apache.openjpa.jdbc.ant
 
MappingToolTask.SchemaAction() - Constructor for class org.apache.openjpa.jdbc.ant.MappingToolTask.SchemaAction
 
mappingWriter - Variable in class org.apache.openjpa.jdbc.meta.MappingTool.Flags
 
mapPrimaryKey(boolean) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Maps the primary key on the secondary table for this field, if the user's defaults create one.
mapRelationToUnmappedPC(ValueMapping, String, boolean) - Static method in class org.apache.openjpa.jdbc.meta.strats.RelationStrategies
Map a logical foreign key to an unmapped base class relation.
MapTableFieldStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Base class for map mappings.
MapTableFieldStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.MapTableFieldStrategy
 
mapTypeNames(MetaDataIterator) - Method in class org.apache.openjpa.lib.meta.ClassArgParser
Return a mapping of each metadata resource to an array of its contained class names.
mapTypes(MetaDataIterator) - Method in class org.apache.openjpa.lib.meta.ClassArgParser
Return a mapping of each metadata resource to an array of its contained classes.
mark(int) - Method in class org.apache.openjpa.lib.xml.DocTypeReader
 
markSupported() - Method in class org.apache.openjpa.lib.xml.DocTypeReader
 
matches(Value, Value, String, String, String) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
matches(Value, Value, String, String, String) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return whether the string matches the matching pattern.
matches(QueryExpressions, ClassMetaData, boolean, Object, StoreContext, Object[]) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
Tests whether the given candidate matches the given type and this expression.
matches(QueryExpressions, Collection, StoreContext, Object[]) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
Return true if the given group matches the having expression.
matches(Value, Value, String, String, String) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
matches(MetaDataFilter.Resource) - Method in class org.apache.openjpa.lib.meta.ClassAnnotationMetaDataFilter
 
matches(MetaDataFilter.Resource) - Method in interface org.apache.openjpa.lib.meta.MetaDataFilter
Return whether the given resource passes the filter.
matches(MetaDataFilter.Resource) - Method in class org.apache.openjpa.lib.meta.SuffixMetaDataFilter
 
matches(String) - Method in class org.apache.openjpa.lib.util.SimpleRegex
 
mathFunction(SQLBuffer, String, FilterValue, FilterValue) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Append the numeric parts of a mathematical function.
max(Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
max - Variable in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq.Status
 
max(Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return the max of the given value for all matches.
max(Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
maxAutoAssignNameLength - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
maxColumnNameLength - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
maxConstraintNameLength - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
MaxEmbeddedBlobFieldStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Mapping for serialized fields on a dictionary that has a maximum embedded BLOB size.
MaxEmbeddedBlobFieldStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedBlobFieldStrategy
 
maxEmbeddedBlobSize - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
MaxEmbeddedByteArrayFieldStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Mapping for byte array fields on a dictionary that has a maximum embedded BLOB size.
MaxEmbeddedByteArrayFieldStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedByteArrayFieldStrategy
 
MaxEmbeddedCharArrayFieldStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Mapping for CLOB character array on a dictionary that has a maximum embedded CLOB size.
MaxEmbeddedCharArrayFieldStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedCharArrayFieldStrategy
 
MaxEmbeddedClobFieldStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Mapping for CLOB string on a dictionary that has a maximum embedded CLOB size.
MaxEmbeddedClobFieldStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedClobFieldStrategy
 
maxEmbeddedClobSize - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
maxFetchDepth - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
maxFetchDepth - Variable in class org.apache.openjpa.kernel.FetchConfigurationImpl.ConfigurationState
 
maxIndexesPerTable - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
maxIndexNameLength - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
maxSize() - Method in class org.apache.openjpa.lib.util.LRUMap
 
maxTableNameLength - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
maybePC(FieldMetaData) - Static method in class org.apache.openjpa.meta.JavaTypes
Return true if the (possibly unresolved) field or its elements might be persistence capable objects.
maybePC(ValueMetaData) - Static method in class org.apache.openjpa.meta.JavaTypes
Return true if the (possibly unresolved) value might be a first class object.
MEDIATE_READ - Static variable in interface org.apache.openjpa.enhance.PersistenceCapable
 
MEDIATE_WRITE - Static variable in interface org.apache.openjpa.enhance.PersistenceCapable
 
memory - Variable in class org.apache.openjpa.kernel.QueryImpl.Compilation
 
merge(T) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
mergeAll(Object...) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
mergeAll(Collection) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
mergeAll(Object...) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Merge the specified objects into the entity manager.
mergeAll(Collection) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Merge the specified detached objects into the entity manager.
mergeColumn(MetaDataContext, String, Column, boolean, Column, Table, boolean, boolean) - Static method in class org.apache.openjpa.jdbc.meta.MappingInfo
Merge the given columns if possible.
MergedResult - Class in org.apache.openjpa.jdbc.sql
Result that merges multiple result delegates.
MergedResult(Result[]) - Constructor for class org.apache.openjpa.jdbc.sql.MergedResult
Constructor; supply delegates.
MergedResult(Result[], MergedResult.ResultComparator) - Constructor for class org.apache.openjpa.jdbc.sql.MergedResult
Constructor; supply delegates and comparator for ordering results.
MergedResult.ResultComparator - Interface in org.apache.openjpa.jdbc.sql
Comparator for ordering result rows.
MergedResultObjectProvider - Class in org.apache.openjpa.lib.rop
A result object provider that merges multiple result object provider delegates.
MergedResultObjectProvider(ResultObjectProvider[]) - Constructor for class org.apache.openjpa.lib.rop.MergedResultObjectProvider
Constructor.
MergedResultObjectProvider(ResultObjectProvider[], Comparator) - Constructor for class org.apache.openjpa.lib.rop.MergedResultObjectProvider
Constructor.
meta - Variable in class org.apache.openjpa.jdbc.meta.MappingTool.Flags
 
METADATA - Static variable in exception org.apache.openjpa.util.UserException
 
MetaDataContext - Interface in org.apache.openjpa.meta
Allows us to access configuration through metadata in a generic way.
MetaDataDefaults - Interface in org.apache.openjpa.meta
Populates new metadata with default values.
MetaDataException - Exception in org.apache.openjpa.util
Exception type reserved for missing or invalid metadata.
MetaDataException() - Constructor for exception org.apache.openjpa.util.MetaDataException
 
MetaDataException(String) - Constructor for exception org.apache.openjpa.util.MetaDataException
 
MetaDataException(Localizer.Message) - Constructor for exception org.apache.openjpa.util.MetaDataException
 
MetaDataException(Localizer.Message, Object) - Constructor for exception org.apache.openjpa.util.MetaDataException
 
MetaDataFactory - Interface in org.apache.openjpa.meta
The MetaDataRepository uses implementations of this interface to load and store metadata.
metaDataFile - Variable in class org.apache.openjpa.jdbc.meta.MappingTool.Flags
 
MetaDataFilter - Interface in org.apache.openjpa.lib.meta
Filters metadata resources.
MetaDataFilter.Resource - Interface in org.apache.openjpa.lib.meta
Information about a metadata resource.
MetaDataInheritanceComparator - Class in org.apache.openjpa.meta
Comparator that keeps metadatas in inheritance order.
MetaDataInheritanceComparator() - Constructor for class org.apache.openjpa.meta.MetaDataInheritanceComparator
 
MetaDataIterator - Interface in org.apache.openjpa.lib.meta
Iterator over metadata resources.
MetaDataIteratorChain - Class in org.apache.openjpa.lib.meta
Metadata iterator that combines several iterators.
MetaDataIteratorChain() - Constructor for class org.apache.openjpa.lib.meta.MetaDataIteratorChain
Default constructor.
MetaDataIteratorChain(MetaDataIterator, MetaDataIterator) - Constructor for class org.apache.openjpa.lib.meta.MetaDataIteratorChain
Combine two iterators.
metaDataLevel - Variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool.Flags
 
MetaDataModes - Interface in org.apache.openjpa.meta
Mode constants used to track the initialization status of metadata.
MetaDataParser - Interface in org.apache.openjpa.lib.meta
Interface for metadata parsers.
MetaDataPlusMappingFactory - Class in org.apache.openjpa.jdbc.meta
Combines two internal MetaDataFactory instances -- one for metadata, one for mappings -- into a single MetaDataFactory facade.
MetaDataPlusMappingFactory(MetaDataFactory, MetaDataFactory) - Constructor for class org.apache.openjpa.jdbc.meta.MetaDataPlusMappingFactory
Constructor; supply delegates.
MetaDataRepository - Class in org.apache.openjpa.meta
Repository of and factory for persistent metadata.
MetaDataRepository() - Constructor for class org.apache.openjpa.meta.MetaDataRepository
Default constructor.
MetaDataSerializer - Interface in org.apache.openjpa.lib.meta
Interface for meta data serializers.
MetaDataTag - Enum in org.apache.openjpa.persistence
Set of metadata tags used in JPA.
MetaDataTool - Class in org.apache.openjpa.meta
Tool for generating default metadata.
MetaDataTool(OpenJPAConfiguration, String) - Constructor for class org.apache.openjpa.meta.MetaDataTool
Constructor.
MetaDataTool.Flags - Class in org.apache.openjpa.meta
Run flags.
MetaDataTool.Flags() - Constructor for class org.apache.openjpa.meta.MetaDataTool.Flags
 
MetaDataToolTask - Class in org.apache.openjpa.ant
Executes the metadata tool on the specified files.
MetaDataToolTask() - Constructor for class org.apache.openjpa.ant.MetaDataToolTask
 
MetaDataToolTask.Action - Class in org.apache.openjpa.ant
 
MetaDataToolTask.Action() - Constructor for class org.apache.openjpa.ant.MetaDataToolTask.Action
 
metaFactoryPlugin - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
metaRepository - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
metaRepositoryPlugin - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
MethodLifecycleCallbacks - Class in org.apache.openjpa.event
Callback adapter that invokes a callback method via reflection.
MethodLifecycleCallbacks(Class, String, boolean) - Constructor for class org.apache.openjpa.event.MethodLifecycleCallbacks
Constructor.
MethodLifecycleCallbacks(Method, boolean) - Constructor for class org.apache.openjpa.event.MethodLifecycleCallbacks
Constructor.
MethodStoreQuery - Class in org.apache.openjpa.kernel
A query that is executed by a user-defined method.
MethodStoreQuery() - Constructor for class org.apache.openjpa.kernel.MethodStoreQuery
 
MICRO - Static variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
MICROSECONDS - Static variable in class org.apache.openjpa.lib.util.concurrent.TimeUnit
 
MILLI - Static variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
MILLISECONDS - Static variable in class org.apache.openjpa.lib.util.concurrent.TimeUnit
 
min(Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
min(Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return the max of the given value for all matches.
min(Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
MINOR_RELEASE - Static variable in class org.apache.openjpa.conf.OpenJPAVersion
 
MINUTES - Static variable in class org.apache.openjpa.lib.util.concurrent.TimeUnit
 
mod(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
mod(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return a value representing the first value mod'd by the second one.
mod(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
mod(Object, Class, Object, Class) - Static method in class org.apache.openjpa.kernel.Filters
Mod the given values.
MODE_ENTRY - Static variable in class org.apache.openjpa.util.Proxies
 
MODE_KEY - Static variable in class org.apache.openjpa.util.Proxies
 
MODE_MAPPING - Static variable in interface org.apache.openjpa.meta.MetaDataModes
 
MODE_MAPPING_INIT - Static variable in interface org.apache.openjpa.meta.MetaDataModes
 
MODE_META - Static variable in interface org.apache.openjpa.meta.MetaDataModes
 
MODE_NONE - Static variable in interface org.apache.openjpa.meta.MetaDataModes
 
MODE_QUERY - Static variable in interface org.apache.openjpa.meta.MetaDataModes
 
MODE_VALUE - Static variable in class org.apache.openjpa.util.Proxies
 
moveToCurrentRow() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
moveToInsertRow() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
MultiClassLoader - Class in org.apache.openjpa.lib.util
Class loader type that can be configured to delegate to multiple internal class loaders.
MultiClassLoader() - Constructor for class org.apache.openjpa.lib.util.MultiClassLoader
Constructor; initializes the loader with an empty list of delegates.
MultiClassLoader(MultiClassLoader) - Constructor for class org.apache.openjpa.lib.util.MultiClassLoader
Construct with the class loaders of another multi loader.
MultiLoaderClassResolver - Class in org.apache.openjpa.util
A simple ClassResolver that uses multiple class loaders to resolve classes.
MultiLoaderClassResolver() - Constructor for class org.apache.openjpa.util.MultiLoaderClassResolver
 
MultiLoaderClassResolver(ClassLoader[]) - Constructor for class org.apache.openjpa.util.MultiLoaderClassResolver
 
MultiLogFactory - Class in org.apache.openjpa.lib.log
A LogFactory implementation to pass events through multiple LogFactory implementations(such as log4j and LogPanelFactory).
MultiLogFactory(LogFactory, LogFactory) - Constructor for class org.apache.openjpa.lib.log.MultiLogFactory
Create an instance with the given delegates.
MultiLogFactory(LogFactory, LogFactory, LogFactory) - Constructor for class org.apache.openjpa.lib.log.MultiLogFactory
Create an instance with the given delegates.
MultiLogFactory(LogFactory[]) - Constructor for class org.apache.openjpa.lib.log.MultiLogFactory
Create an instance with the given delegates.
multiply(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
multiply(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return a value representing the two values multiplied together.
multiply(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
multiply(Object, Class, Object, Class) - Static method in class org.apache.openjpa.kernel.Filters
Multiply the given values.
multithreaded - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
MySQLDictionary - Class in org.apache.openjpa.jdbc.sql
Dictionary for MySQL.
MySQLDictionary() - Constructor for class org.apache.openjpa.jdbc.sql.MySQLDictionary
 

N

name - Variable in class org.apache.openjpa.enhance.ApplicationIdTool.Flags
 
NAME_ALL - Static variable in class org.apache.openjpa.meta.FetchGroup
Name of the "all" fetch group.
NAME_ANY - Static variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
NAME_DEFAULT - Static variable in interface org.apache.openjpa.datacache.DataCache
The name of the default data cache: default
NAME_DEFAULT - Static variable in class org.apache.openjpa.meta.FetchGroup
Name of the default fetch group.
NAME_DEFAULT - Static variable in interface org.apache.openjpa.persistence.StoreCache
 
NAME_SEQUENCE - Static variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
NAME_SYSTEM - Static variable in class org.apache.openjpa.meta.SequenceMetaData
Sequence name that means to use the system default sequence.
NAME_TABLE - Static variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
namedHandler(ValueMapping) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Instantiate the given value's named handler, or return null if no named handler.
namedSequenceFromOneSchemaSQL - Variable in class org.apache.openjpa.jdbc.sql.PostgresDictionary
SQL statement to load a sequence's schema,name pair from one schema.
namedSequencesFromAllSchemasSQL - Variable in class org.apache.openjpa.jdbc.sql.PostgresDictionary
SQL statement to load schema,name pairs for all sequences with a certain name from all schemas.
namedStrategy(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Instantiate the given class' named strategy, or return null if no named strategy.
namedStrategy(FieldMapping, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Instantiate the given field's named strategy, or return null if no named strategy.
namedStrategy(Discriminator) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Instantiate the given discriminator's named strategy, or return null if no named strategy.
namedStrategy(Version) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Instantiate the given version's named strategy, or return null if no named strategy.
NameSet - Class in org.apache.openjpa.jdbc.schema
Name sets track what names have been taken, ignoring case.
NameSet() - Constructor for class org.apache.openjpa.jdbc.schema.NameSet
 
NANO - Static variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
NANOSECONDS - Static variable in class org.apache.openjpa.lib.util.concurrent.TimeUnit
 
nanoTime() - Method in interface org.apache.openjpa.lib.util.concurrent.NanoTimer
Returns the current value of the most precise available system timer, in nanoseconds.
nanoTime() - Static method in class org.apache.openjpa.lib.util.concurrent.Utils
Returns the current value of the most precise available system timer, in nanoseconds.
NanoTimer - Interface in org.apache.openjpa.lib.util.concurrent
Interface to specify custom implementation of precise timer.
NATIVE - Static variable in class org.apache.openjpa.meta.ValueStrategies
"native" value strategy.
NativeJDBCSeq - Class in org.apache.openjpa.jdbc.kernel
JDBCSeq implementation that uses a database sequences to generate numbers.
NativeJDBCSeq() - Constructor for class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
 
nativeSQL(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
newAggregate(AggregateListener, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
newAggregate(AggregateListener, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return the value of the given function.
newAggregate(AggregateListener, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
newAnnotationParser() - Method in class org.apache.openjpa.persistence.jdbc.PersistenceMappingFactory
 
newAnnotationParser() - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
Create a new metadata parser.
newArgumentList(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
newArgumentList(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return a function argument list consisting of the given values, either of which may itself be an argument list.
newArgumentList(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
newBoundVariable(String, Class) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
newBoundVariable(String, Class) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
This method will be called only once per variable bound in a contains clause, and the returned value will be reused for any further instances of the variable in subexpression of the filter string.
newBoundVariable(String, Class) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
newBroker() - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
 
newBroker(String, String) - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
 
newBroker(boolean, int) - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
 
newBroker(String, String, boolean, int) - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
 
newBroker(String, String, boolean, int, boolean) - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
 
newBroker() - Method in interface org.apache.openjpa.kernel.BrokerFactory
Return a broker with default settings.
newBroker(String, String, boolean, int, boolean) - Method in interface org.apache.openjpa.kernel.BrokerFactory
Return a broker using the given credentials and in the given transaction and connection retain mode, optionally finding existing broker in the global transaction.
newBroker() - Method in class org.apache.openjpa.kernel.DelegatingBrokerFactory
 
newBroker(String, String, boolean, int, boolean) - Method in class org.apache.openjpa.kernel.DelegatingBrokerFactory
 
newBrokerFactory() - Static method in class org.apache.openjpa.kernel.Bootstrap
Return a new factory for the default configuration.
newBrokerFactory(ConfigurationProvider, ClassLoader) - Static method in class org.apache.openjpa.kernel.Bootstrap
Return a new factory for the given configuration.
newBrokerImpl(String, String) - Method in class org.apache.openjpa.jdbc.kernel.JDBCBrokerFactory
 
newBrokerImpl(String, String) - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
Return a broker configured with the proper settings.
newBrokerInstance(String, String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Create a new broker instance with the configured plugin data.
newBrokerInstance(String, String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
newBrokerInstance(String, String) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
newCacheMap() - Method in class org.apache.openjpa.datacache.ConcurrentDataCache
Return the map to use as an internal cache; entry expirations must invoke AbstractDataCache.keyRemoved(java.lang.Object, boolean).
newCacheMap() - Method in class org.apache.openjpa.datacache.ConcurrentQueryCache
Return the map to use as an internal cache.
newCalendarProxy(Class, TimeZone) - Method in interface org.apache.openjpa.util.ProxyManager
Return a new calendar proxy.
newCalendarProxy(Class, TimeZone) - Method in class org.apache.openjpa.util.ProxyManagerImpl
 
newClassArgParser() - Method in class org.apache.openjpa.meta.AbstractMetaDataFactory
 
newClassArgParser() - Method in class org.apache.openjpa.meta.DelegatingMetaDataFactory
 
newClassArgParser() - Method in interface org.apache.openjpa.meta.MetaDataFactory
Return a properly-configured class arg parser for our expected metadata format.
newClassArgParser() - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
newClassArgParser() - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
 
newClassMapping(Class, Table) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Create a new class to be mapped to a table.
newClassMetaData(Class) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
 
newClassMetaData(Class) - Method in class org.apache.openjpa.meta.MetaDataRepository
Create a new class metadata instance.
newClassMetaDataArray(int) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
 
newClassMetaDataArray(int) - Method in class org.apache.openjpa.meta.MetaDataRepository
Create a new array of the proper class metadata subclass.
newCodeFormat() - Method in class org.apache.openjpa.enhance.CodeGenerator
Return a copy of the internal code format.
newCollectionProxy(Class, Class, Comparator) - Method in interface org.apache.openjpa.util.ProxyManager
Return a proxy for the given collection type.
newCollectionProxy(Class, Class, Comparator) - Method in class org.apache.openjpa.util.ProxyManagerImpl
 
newColumn(String, Table) - Method in class org.apache.openjpa.jdbc.schema.DynamicSchemaFactory
 
newColumn(String, Table) - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Return a new column with the given name and owner table.
newColumn(ResultSet) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Create a new column from the information in the schema metadata.
newColumn(ResultSet) - Method in class org.apache.openjpa.jdbc.sql.InformixDictionary
 
newColumn(ResultSet) - Method in class org.apache.openjpa.jdbc.sql.MySQLDictionary
 
newCompilation() - Method in class org.apache.openjpa.datacache.QueryCacheStoreQuery
 
newCompilation() - Method in class org.apache.openjpa.kernel.AbstractStoreQuery
 
newCompilation() - Method in class org.apache.openjpa.kernel.ExpressionStoreQuery
 
newCompilation() - Method in interface org.apache.openjpa.kernel.StoreQuery
Create a new compilation for this query.
newCompilationKey() - Method in class org.apache.openjpa.datacache.QueryCacheStoreQuery
 
newCompilationKey() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreQuery
 
newCompilationKey() - Method in class org.apache.openjpa.kernel.AbstractStoreQuery
 
newCompilationKey() - Method in interface org.apache.openjpa.kernel.StoreQuery
Create a new key for caching compiled query information.
newCondition() - Method in interface org.apache.openjpa.lib.util.concurrent.Lock
Returns a new Condition instance that is bound to this Lock instance.
newCondition() - Method in class org.apache.openjpa.lib.util.concurrent.ReentrantLock
Returns a Condition instance for use with this Lock instance.
newConfiguration() - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
Return a new configuration instance for this runtime.
newConfiguration() - Method in class org.apache.openjpa.ant.ApplicationIdToolTask
 
newConfiguration() - Method in class org.apache.openjpa.ant.MetaDataToolTask
 
newConfiguration() - Method in class org.apache.openjpa.ant.PCEnhancerTask
 
newConfiguration() - Method in class org.apache.openjpa.jdbc.ant.MappingToolTask
 
newConfiguration() - Method in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
 
newConfiguration() - Method in class org.apache.openjpa.jdbc.ant.SchemaToolTask
 
newConfiguration() - Method in class org.apache.openjpa.lib.ant.AbstractTask
Implement this method to return a configuration object for the product in use.
newConfiguration() - Method in class org.apache.openjpa.xmlstore.XMLStoreManager
 
newContext() - Method in class org.apache.openjpa.event.JMSRemoteCommitProvider
Returns a new Context object for use by this provider.
newCustomProxy(Object) - Method in interface org.apache.openjpa.util.ProxyManager
Return a proxy for the given object, or null if this manager cannot proxy the object.
newCustomProxy(Object) - Method in class org.apache.openjpa.util.ProxyManagerImpl
 
newDataSource(JDBCConfiguration, boolean) - Static method in class org.apache.openjpa.jdbc.schema.DataSourceFactory
Create a datasource using the given configuration.
newDataStoreExecutor(ClassMetaData, boolean) - Method in class org.apache.openjpa.datacache.QueryCacheStoreQuery
 
newDataStoreExecutor(ClassMetaData, boolean) - Method in class org.apache.openjpa.jdbc.kernel.SQLStoreQuery
 
newDataStoreExecutor(ClassMetaData, boolean) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery
 
newDataStoreExecutor(ClassMetaData, boolean) - Method in class org.apache.openjpa.kernel.ExpressionStoreQuery
 
newDataStoreExecutor(ClassMetaData, boolean) - Method in class org.apache.openjpa.kernel.MethodStoreQuery
 
newDataStoreExecutor(ClassMetaData, boolean) - Method in interface org.apache.openjpa.kernel.StoreQuery
Return an executor for datastore execution of this query.
newDataStoreId(Object, ClassMetaData) - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
 
newDataStoreId(long, ClassMapping, boolean) - Method in interface org.apache.openjpa.jdbc.kernel.JDBCStore
Create a new datastore identity object from the given id value and mapping.
newDataStoreId(Object, ClassMetaData) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
newDataStoreId(long, ClassMapping, boolean) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
newDataStoreId(Object, ClassMetaData) - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
newDataStoreId(Object, ClassMetaData) - Method in interface org.apache.openjpa.kernel.StoreManager
Create a new unique datastore identity for the given type from the given oid value (presumably pk, stringified oid, or oid instance).
newDateProxy(Class) - Method in interface org.apache.openjpa.util.ProxyManager
Return a new date proxy.
newDateProxy(Class) - Method in class org.apache.openjpa.util.ProxyManagerImpl
 
newDBDictionary(JDBCConfiguration, String, String) - Static method in class org.apache.openjpa.jdbc.sql.DBDictionaryFactory
Create the dictionary for the given class name and properties.
newDBDictionary(JDBCConfiguration, DataSource, String) - Static method in class org.apache.openjpa.jdbc.sql.DBDictionaryFactory
Create the dictionary using connection metadata to determine its type.
newDelegatingFetchConfiguration(FetchConfiguration) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
Create a new exception-translating delegating fetch configuration.
newDelegatingFetchConfiguration(FetchConfiguration) - Method in class org.apache.openjpa.persistence.jdbc.JDBCFetchPlanImpl
 
newDiscriminator(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Create discriminator metadata for the given class.
newDriverDataSourceInstance() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Create an instance of the DriverDataSource to use for creating a DataSource from a JDBC Driver.
newDriverDataSourceInstance() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
newEmbeddedClassMetaData(ValueMetaData) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
 
newEmbeddedClassMetaData(ValueMetaData) - Method in class org.apache.openjpa.meta.MetaDataRepository
Create a new embedded class metadata instance.
newEmbeddedPCData(OpenJPAStateManager) - Method in class org.apache.openjpa.datacache.DataCachePCDataImpl
 
newEmbeddedPCData(OpenJPAStateManager) - Method in class org.apache.openjpa.kernel.AbstractPCData
Create a new pcdata for holding the state of an embedded instance.
newEmbeddedPCData(OpenJPAStateManager) - Method in class org.apache.openjpa.kernel.PCDataImpl
Return a new PCData implementation of the right type for embedded instances.
newEntityManagerImpl(Broker) - Method in class org.apache.openjpa.persistence.EntityManagerFactoryImpl
Create a new entity manager around the given broker.
newExtension(FilterListener, Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
newExtension(FilterListener, Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return the value of the given extension.
newExtension(FilterListener, Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
newExtent(Class, boolean) - Method in interface org.apache.openjpa.kernel.Broker
Return an extent of the given class, optionally including subclasses.
newExtent(Class, boolean) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
newExtent(Class, boolean) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
newFactory(BrokerFactory) - Static method in class org.apache.openjpa.persistence.EntityManagerFactoryValue
Create a new factory of the configured type.
newFetchConfiguration() - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
 
newFetchConfiguration() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
newFetchConfiguration() - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
newFetchConfiguration() - Method in interface org.apache.openjpa.kernel.StoreManager
Return a fetch configuration suitable for this runtime.
newFieldMapping(String, Class, Column, ForeignKey, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Create a field mapping for the given info, or return null if customizer rejects.
newFieldMetaData(String, Class, ClassMetaData) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
 
newFieldMetaData(String, Class, ClassMetaData) - Method in class org.apache.openjpa.meta.MetaDataRepository
Create a new field metadata instance.
newFieldMetaDataArray(int) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
 
newFieldMetaDataArray(int) - Method in class org.apache.openjpa.meta.MetaDataRepository
Create a new array of the proper field metadata subclass.
newFieldProxy(int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
newFieldProxy(int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
newFieldProxy(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
newFieldProxy(int) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Create a new hollow proxy instance for the given field.
newFieldProxy(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
newFilterValues(Select, ExpContext, ExpState) - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
Return a filter value for each argument.
newForeignKey(String, Table) - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Return a new foreign key with the given name and owner table.
newForeignKey(ResultSet) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Create a new foreign key from the information in the schema metadata.
newImage(int) - Static method in class org.apache.openjpa.util.ArrayStateImage
Create a new state image for the given number of fields.
newIndex(String, Table) - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Return a new index with the given name and owner table.
newIndex(ResultSet) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Create a new index from the information in the schema metadata.
newIndex(ResultSet) - Method in class org.apache.openjpa.jdbc.sql.InformixDictionary
 
newInMemoryExecutor(ClassMetaData, boolean) - Method in class org.apache.openjpa.datacache.QueryCacheStoreQuery
 
newInMemoryExecutor(ClassMetaData, boolean) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery
 
newInMemoryExecutor(ClassMetaData, boolean) - Method in class org.apache.openjpa.kernel.ExpressionStoreQuery
 
newInMemoryExecutor(ClassMetaData, boolean) - Method in class org.apache.openjpa.kernel.MethodStoreQuery
 
newInMemoryExecutor(ClassMetaData, boolean) - Method in interface org.apache.openjpa.kernel.StoreQuery
Return an executor for in-memory execution of this query.
newInstance(ConfigurationProvider) - Static method in class org.apache.openjpa.abstractstore.AbstractStoreBrokerFactory
Factory method for constructing a BrokerFactory from properties.
newInstance(String, Class, Configuration, boolean) - Method in class org.apache.openjpa.conf.QueryCompilationCacheValue
 
newInstance(Query) - Static method in class org.apache.openjpa.datacache.QueryKey
Return a key for the given query, or null if it is not cacheable.
newInstance(Query, Object[]) - Static method in class org.apache.openjpa.datacache.QueryKey
Return a key for the given query, or null if it is not cacheable.
newInstance(Query, Map) - Static method in class org.apache.openjpa.datacache.QueryKey
Return a key for the given query, or null if it is not cacheable.
newInstance() - Method in interface org.apache.openjpa.enhance.DynamicStorage
Factory method for getting new instances of the same definition.
newInstance(Class, StateManager, boolean) - Static method in class org.apache.openjpa.enhance.PCRegistry
Create a new instance of the class and assign its state manager.
newInstance(Class, StateManager, Object, boolean) - Static method in class org.apache.openjpa.enhance.PCRegistry
Create a new instance of the class and assign its state manager and oid.
newInstance(String, Class, Configuration, boolean) - Method in class org.apache.openjpa.jdbc.conf.MappingRepositoryValue
 
newInstance(ConfigurationProvider) - Static method in class org.apache.openjpa.jdbc.kernel.JDBCBrokerFactory
Factory method for constructing a factory from properties.
newInstance(FetchConfigurationImpl.ConfigurationState) - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
newInstance(Table, int) - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy.CustomUpdate
 
newInstance() - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Create a new instance of this class.
newInstance(Table, int) - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
 
newInstance(Table, int) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
Return a new row.
newInstance(Table, int) - Method in class org.apache.openjpa.jdbc.sql.SecondaryRow
 
newInstance(Class) - Method in interface org.apache.openjpa.kernel.Broker
Create a new instance of type cls.
newInstance(Class) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
newInstance(Class) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
newInstance(FetchConfigurationImpl.ConfigurationState) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
Return a new hollow instance.
newInstance(String, ClassLoader) - Static method in class org.apache.openjpa.lib.conf.Configurations
Create the instance with the given class name, using the given class loader.
newInstance(String, Configuration, String, ClassLoader) - Static method in class org.apache.openjpa.lib.conf.Configurations
Create and configure an instance with the given class name and properties.
newInstance(String, Class, Configuration, boolean) - Method in class org.apache.openjpa.lib.conf.ObjectValue
Allow subclasses to instantiate additional plugins.
newInstance(Class, Object) - Static method in class org.apache.openjpa.util.Id
Create an id from the given type and value; the value might be an id instnace, a stringified id, or a primary key value.
newInstance(Class, Comparator, boolean, OpenJPAConfiguration) - Method in class org.apache.openjpa.util.ProxyArrayList
 
newInstance(TimeZone) - Method in interface org.apache.openjpa.util.ProxyCalendar
Return a new instance of this calendar type.
newInstance(Class, Comparator, boolean, OpenJPAConfiguration) - Method in interface org.apache.openjpa.util.ProxyCollection
This method should return a new proxy of the same concrete type as the implementing class.
newInstance() - Method in interface org.apache.openjpa.util.ProxyDate
Return a new instance of this date type.
newInstance(TimeZone) - Method in class org.apache.openjpa.util.ProxyGregorianCalendar
 
newInstance(Class, Class, Comparator, boolean, OpenJPAConfiguration) - Method in class org.apache.openjpa.util.ProxyHashMap
 
newInstance(Class, Comparator, boolean, OpenJPAConfiguration) - Method in class org.apache.openjpa.util.ProxyHashSet
 
newInstance(Class, Class, Comparator, boolean, OpenJPAConfiguration) - Method in class org.apache.openjpa.util.ProxyHashtable
 
newInstance(Class, Comparator, boolean, OpenJPAConfiguration) - Method in class org.apache.openjpa.util.ProxyLinkedList
 
newInstance(Class, Class, Comparator, boolean, OpenJPAConfiguration) - Method in interface org.apache.openjpa.util.ProxyMap
This method should return a new proxy of the same concrete type as the implementing class.
newInstance(Class, Class, Comparator, boolean, OpenJPAConfiguration) - Method in class org.apache.openjpa.util.ProxyProperties
 
newInstance() - Method in class org.apache.openjpa.util.ProxySQLDate
 
newInstance() - Method in class org.apache.openjpa.util.ProxyTime
 
newInstance() - Method in class org.apache.openjpa.util.ProxyTimestamp
 
newInstance(Class, Class, Comparator, boolean, OpenJPAConfiguration) - Method in class org.apache.openjpa.util.ProxyTreeMap
 
newInstance(Class, Comparator, boolean, OpenJPAConfiguration) - Method in class org.apache.openjpa.util.ProxyTreeSet
 
newInstance() - Method in class org.apache.openjpa.util.ProxyUtilDate
 
newInstance(Class, Comparator, boolean, OpenJPAConfiguration) - Method in class org.apache.openjpa.util.ProxyVector
 
newInverseManagerInstance() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Return a new inverse manager instance using the configured plugin settings.
newInverseManagerInstance() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
newJoins() - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
Returns a no-op joins object by default.
newJoins() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
newJoins() - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
newJoins() - Method in interface org.apache.openjpa.jdbc.sql.Result
Return a new joins instance to use for traversing to related data.
newJoins() - Method in interface org.apache.openjpa.jdbc.sql.Select
Return a new instance to use for joining.
newJoins() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
newJoins() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
newListenerCollection() - Method in class org.apache.openjpa.datacache.AbstractQueryCache
Individual query results will be registered as types changed listeners.
newListenerCollection() - Method in class org.apache.openjpa.lib.util.AbstractEventManager
Return a new container for listeners.
newListenerCollection() - Method in class org.apache.openjpa.lib.util.concurrent.AbstractConcurrentEventManager
Return a new concurrent container for listeners.
newLiteral(Object, int) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
newLiteral(Object, int) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return a value representing the given constant, which will be a Number, String, or Boolean instance.
newLiteral(Object, int) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
newLockManagerInstance() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Return a new lock manager instance using the configured plugin settings.
newLockManagerInstance() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
newLogAdapter(String) - Method in class org.apache.openjpa.lib.log.CommonsLogFactory
 
newLogAdapter(String) - Method in class org.apache.openjpa.lib.log.Log4JLogFactory
 
newLogAdapter(String) - Method in class org.apache.openjpa.lib.log.LogFactoryAdapter
Return a log adapter for the given channel.
newLogImpl() - Method in class org.apache.openjpa.lib.log.LogFactoryImpl
Create a new log.
newLRSProxy(OpenJPAConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationCollectionInverseKeyFieldStrategy
 
newLRSProxy(OpenJPAConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationCollectionTableFieldStrategy
 
newLRSProxy(OpenJPAConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapInverseKeyFieldStrategy
 
newLRSProxy(OpenJPAConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapTableFieldStrategy
 
newLRSProxy(OpenJPAConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.StoreCollectionFieldStrategy
Return a large result set proxy for this field.
newManagedObjectCache() - Method in class org.apache.openjpa.kernel.BrokerImpl
Create a Map to be used for the primary managed object cache.
newMappingInfo(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Create raw mapping info for the given instance.
newMappingInfo(FieldMapping) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Create raw mapping info for the given instance.
newMappingInfo(ValueMapping) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Create raw mapping info for the given instance.
newMappingInfo(Version) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Create raw mapping info for the given instance.
newMappingInfo(Discriminator) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Create raw mapping info for the given instance.
newMappingRepositoryInstance() - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Return a new empty mapping repository of the configured type.
newMappingRepositoryInstance() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
newMapProxy(Class, Class, Class, Comparator) - Method in interface org.apache.openjpa.util.ProxyManager
Return a proxy for the given map type.
newMapProxy(Class, Class, Class, Comparator) - Method in class org.apache.openjpa.util.ProxyManagerImpl
 
newMetaDataFactoryInstance() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Create a new MetaDataFactory to use with a repository.
newMetaDataFactoryInstance() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
newMetaDataFactoryInstance() - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
newMetaDataFilter() - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Return a metadata filter that identifies metadata resources when performing jar and classpath scans.
newMetaDataFilter() - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
 
newMetaDataRepositoryInstance() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Create a new empty metadata repository of the configured type.
newMetaDataRepositoryInstance() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
newObjectId(Class) - Static method in class org.apache.openjpa.enhance.PCRegistry
Create a new identity object for the given PersistenceCapable class.
newObjectId(Class, String) - Static method in class org.apache.openjpa.enhance.PCRegistry
Create a new identity object for the given PersistenceCapable class, using the String form of the constructor.
newObjectId(Class, Object) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
newObjectId(Class, Object) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
newObjectId(Class, Object) - Method in interface org.apache.openjpa.kernel.StoreContext
Create a new object id instance from the given value.
newOrder(FieldMetaData, String, boolean) - Method in class org.apache.openjpa.meta.MetaDataRepository
Create an Order for the given field and declaration.
newOrderArray(int) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
 
newOrderArray(int) - Method in class org.apache.openjpa.meta.MetaDataRepository
Create an array of orders of the given size.
newOuterJoins() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
newOuterJoins() - Method in interface org.apache.openjpa.jdbc.sql.Select
Return a new instance to use for outer joining.
newOuterJoins() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
newParameter(String, Class) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
newParameter(String, Class) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return a value representing a parameter for the given value.
newParameter(String, Class) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
newParser(boolean) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Create a new metadata parser.
newParser(boolean) - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
 
newPath() - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
newPath(Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
newPath() - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return a value representing a path which will consist of a chain of 1 or more field names starting in the namespace of the candidate class.
Example: parent.address.city
newPath(Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return a value representing a path which will consist of a chain of 1 or more field names starting in the namespace of the given value.
Example: var.address.city
newPath() - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
newPath(Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
newPluginValue(String) - Method in class org.apache.openjpa.jdbc.meta.SequenceMapping
 
newPluginValue(String) - Method in class org.apache.openjpa.meta.SequenceMetaData
Create a new plugin value for sequences.
newPreparedStatementManager(JDBCStore, Connection) - Method in class org.apache.openjpa.jdbc.kernel.AbstractUpdateManager
Return a new PreparedStatementManager.
newPreparedStatementManager(JDBCStore, Connection) - Method in class org.apache.openjpa.jdbc.kernel.OperationOrderUpdateManager
 
newPrimaryKey(String, Table) - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Return a new primary key with the given name and owner table.
newPrimaryKey(ResultSet) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Create a new primary key from the information in the schema metadata.
newPrimaryKey(ResultSet) - Method in class org.apache.openjpa.jdbc.sql.InformixDictionary
 
newProxy(int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
newProxy(int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
newProxy(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
newProxy(int) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Create a new hollow proxy instance for the given field.
newProxy(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
newQuery(String) - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
 
newQuery(String) - Method in class org.apache.openjpa.datacache.DataCacheStoreManager
 
newQuery(String) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
newQuery(String, Class, Object) - Method in interface org.apache.openjpa.kernel.Broker
Create a new query from the given data, with the given candidate class and language.
newQuery(String, Object) - Method in interface org.apache.openjpa.kernel.Broker
Create a new query in the given language.
newQuery(String, Class, Object) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
newQuery(String, Object) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
newQuery(String, Class, Object) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
newQuery(String, Object) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
newQuery(String) - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
newQuery(String) - Method in interface org.apache.openjpa.kernel.StoreManager
Return a query implementation suitable for this store.
newQueryImpl(String, StoreQuery) - Method in class org.apache.openjpa.kernel.BrokerImpl
Create a new query.
newQueryMetaData(Class, String) - Method in class org.apache.openjpa.meta.MetaDataRepository
Create a new query metadata instance.
newRelatedFieldOrder(FieldMetaData, FieldMetaData, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
 
newRelatedFieldOrder(FieldMetaData, FieldMetaData, boolean) - Method in class org.apache.openjpa.meta.MetaDataRepository
Order by a field of the related type.
newRemoteCommitProviderInstance() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Create a remote commit provider from the configured plugin.
newRemoteCommitProviderInstance() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
newRepository() - Method in class org.apache.openjpa.meta.MetaDataTool
Create a new metadata repository.
newResultList(ResultObjectProvider) - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
newResultList(ResultObjectProvider) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
newResultList(ResultObjectProvider) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Return a new result list for the current fetch configuration.
newResultList(ResultObjectProvider) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
newRowManager() - Method in class org.apache.openjpa.jdbc.kernel.AbstractUpdateManager
Return a new RowManager.
newRowManager() - Method in class org.apache.openjpa.jdbc.kernel.OperationOrderUpdateManager
 
newRowMap() - Method in class org.apache.openjpa.lib.rop.RandomAccessResultList
Override this method to control what kind of map is used for the instantiated rows.
newRowMap() - Method in class org.apache.openjpa.lib.rop.SoftRandomAccessResultList
 
newSavepoint(String, Broker) - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSavepointManager
 
newSavepoint(String, Broker) - Method in class org.apache.openjpa.kernel.InMemorySavepointManager
 
newSavepoint(String, Broker) - Method in interface org.apache.openjpa.kernel.SavepointManager
Return a new savepoint for the given name, which may be null.
newSchema(String) - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Return a new schema with the given name.
newSelect() - Method in interface org.apache.openjpa.jdbc.sql.SQLFactory
Select factory.
newSelect() - Method in class org.apache.openjpa.jdbc.sql.SQLFactoryImpl
 
newSequence(String, Schema) - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Return a new sequence with the given name and owner schema.
newSequence(ResultSet) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Create a new sequence from the information in the schema metadata.
newSequenceMetaData(String) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
 
newSequenceMetaData(String) - Method in class org.apache.openjpa.meta.MetaDataRepository
Create a new sequence metadata instance.
newSerializationComparator() - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer
 
newSerializationComparator() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Create a new comparator for ordering objects that are to be serialized.
newSerializer() - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Create a new metadata serializer.
newSerializer() - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
 
newSet() - Method in class org.apache.openjpa.util.AbstractChangeTracker
Create a new set for storing adds/removes/changes.
newStateManagerImpl(Object, ClassMetaData) - Method in class org.apache.openjpa.kernel.BrokerImpl
Create a state manager for the given oid and metadata.
newStoreException(String, SQLException[], Object) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return a new exception that wraps causes.
newStoreException(String, SQLException[], Object) - Method in class org.apache.openjpa.jdbc.sql.HSQLDictionary
 
newStoreException(String, SQLException[], Object) - Method in class org.apache.openjpa.jdbc.sql.JDataStoreDictionary
 
newStoreManager() - Method in class org.apache.openjpa.abstractstore.AbstractStoreBrokerFactory
 
newStoreManager() - Method in class org.apache.openjpa.jdbc.kernel.JDBCBrokerFactory
 
newStoreManager() - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
Return a new StoreManager for this runtime.
newSubquery(ClassMetaData, boolean, String) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
newSubquery(ClassMetaData, boolean, String) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return a subquery.
newSubquery(ClassMetaData, boolean, String) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
newTable(String, Schema) - Method in class org.apache.openjpa.jdbc.schema.DynamicSchemaFactory
 
newTable(String, Schema) - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Return a new table with the given name and owner schema.
newTable(ResultSet) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Create a new table from the information in the schema metadata.
newUnboundVariable(String, Class) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
newUnboundVariable(String, Class) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return an unbound variable.
newUnboundVariable(String, Class) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
newUnion(int) - Method in interface org.apache.openjpa.jdbc.sql.SQLFactory
Union factory.
newUnion(Select[]) - Method in interface org.apache.openjpa.jdbc.sql.SQLFactory
Union factory.
newUnion(int) - Method in class org.apache.openjpa.jdbc.sql.SQLFactoryImpl
 
newUnion(Select[]) - Method in class org.apache.openjpa.jdbc.sql.SQLFactoryImpl
 
newUnionSelect(SelectImpl, int) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
Create a new union select with the given delegate and union position.
newUnique(String, Table) - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Return a new unique constraint with the given name and owner table.
newValueMetaData(FieldMetaData) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
 
newValueMetaData(FieldMetaData) - Method in class org.apache.openjpa.meta.MetaDataRepository
Create a new value metadata instance.
newValueOrder(FieldMetaData, boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
 
newValueOrder(FieldMetaData, boolean) - Method in class org.apache.openjpa.meta.MetaDataRepository
Order by the field value.
newVersion(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Create version metadata for the given class.
newXMLParser(boolean) - Method in class org.apache.openjpa.persistence.jdbc.PersistenceMappingFactory
 
newXMLParser(boolean) - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
Create a new metadata parser.
newXMLSerializer() - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
Create a new serializer
next(StoreContext, ClassMetaData) - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSeq
 
next() - Method in class org.apache.openjpa.jdbc.kernel.GenericResultObjectProvider
 
next() - Method in class org.apache.openjpa.jdbc.kernel.PagingResultObjectProvider
 
next() - Method in class org.apache.openjpa.jdbc.kernel.SelectResultObjectProvider
 
next() - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
next() - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
next() - Method in interface org.apache.openjpa.jdbc.sql.Result
Advance to the next row, or return false if there are no more rows in the result.
next() - Method in class org.apache.openjpa.kernel.AbstractPCResultObjectProvider
Implement this method to advance the input.
next() - Method in class org.apache.openjpa.kernel.DelegatingResultList.DelegatingListIterator
 
next(StoreContext, ClassMetaData) - Method in class org.apache.openjpa.kernel.DelegatingSeq
 
next(StoreContext, ClassMetaData) - Method in interface org.apache.openjpa.kernel.Seq
Return the next value in the sequence.
next(StoreContext, ClassMetaData) - Method in class org.apache.openjpa.kernel.TimeSeededSeq
 
next(StoreContext, ClassMetaData) - Method in class org.apache.openjpa.kernel.UUIDHexSeq
 
next(StoreContext, ClassMetaData) - Method in class org.apache.openjpa.kernel.UUIDStringSeq
 
next() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
next() - Method in class org.apache.openjpa.lib.meta.ClassMetaDataIterator
 
next() - Method in class org.apache.openjpa.lib.meta.FileMetaDataIterator
 
next() - Method in interface org.apache.openjpa.lib.meta.MetaDataIterator
Return the next metadata resource.
next() - Method in class org.apache.openjpa.lib.meta.MetaDataIteratorChain
 
next() - Method in class org.apache.openjpa.lib.meta.ResourceMetaDataIterator
 
next() - Method in class org.apache.openjpa.lib.meta.URLMetaDataIterator
 
next() - Method in class org.apache.openjpa.lib.meta.ZipFileMetaDataIterator
 
next() - Method in class org.apache.openjpa.lib.meta.ZipStreamMetaDataIterator
 
next() - Method in class org.apache.openjpa.lib.rop.ListResultObjectProvider
 
next() - Method in class org.apache.openjpa.lib.rop.MergedResultObjectProvider
 
next() - Method in class org.apache.openjpa.lib.rop.RangeResultObjectProvider
 
next() - Method in class org.apache.openjpa.lib.rop.ResultListIterator
 
next() - Method in interface org.apache.openjpa.lib.rop.ResultObjectProvider
Advance the input to the next position.
next() - Method in class org.apache.openjpa.lib.rop.ResultObjectProviderIterator
 
next() - Static method in class org.apache.openjpa.lib.util.UUIDGenerator
Return a unique UUID value.
next() - Method in interface org.apache.openjpa.persistence.Generator
The next sequence value.
next() - Method in class org.apache.openjpa.persistence.GeneratorImpl
 
nextHex() - Static method in class org.apache.openjpa.lib.util.UUIDGenerator
Return the next unique uuid value as a 32-character hex string.
nextIndex() - Method in class org.apache.openjpa.kernel.DelegatingResultList.DelegatingListIterator
 
nextIndex() - Method in class org.apache.openjpa.lib.rop.ResultListIterator
 
nextInternal(JDBCStore, ClassMapping) - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSeq
Return the next sequence object.
nextInternal(JDBCStore, ClassMapping) - Method in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
 
nextInternal(JDBCStore, ClassMapping) - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
 
nextInternal() - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
Advance this row.
nextInternal() - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
nextInternal() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
nextSequenceQuery - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
nextString() - Static method in class org.apache.openjpa.lib.util.UUIDGenerator
Return the next unique uuid value as a 16-character string.
nextVersion(Object) - Method in class org.apache.openjpa.jdbc.meta.strats.ColumnVersionStrategy
Return the next version given the current one, which may be null.
nextVersion(Object) - Method in class org.apache.openjpa.jdbc.meta.strats.NumberVersionStrategy
 
nextVersion(Object) - Method in class org.apache.openjpa.jdbc.meta.strats.TimestampVersionStrategy
 
NO_TRANSACTION - Static variable in exception org.apache.openjpa.util.UserException
 
NONE - Static variable in class org.apache.openjpa.kernel.InverseManager
 
NONE - Static variable in class org.apache.openjpa.meta.UpdateStrategies
No update strategy.
NONE - Static variable in class org.apache.openjpa.meta.ValueStrategies
No value strategy.
NoneClassStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Strategy for classes that aren't mapped.
NoneDiscriminatorStrategy - Class in org.apache.openjpa.jdbc.meta.strats
No-op Discriminator strategy.
NoneFieldStrategy - Class in org.apache.openjpa.jdbc.meta.strats
An unmapped field.
NoneLockManager - Class in org.apache.openjpa.kernel
A lock manager that does not perform any locking.
NoneLockManager() - Constructor for class org.apache.openjpa.kernel.NoneLockManager
 
NoneLogFactory - Class in org.apache.openjpa.lib.log
A log factory implementation that does not do any logging, as quickly as possible.
NoneLogFactory() - Constructor for class org.apache.openjpa.lib.log.NoneLogFactory
 
NoneLogFactory.NoneLog - Class in org.apache.openjpa.lib.log
No-op log.
NoneLogFactory.NoneLog() - Constructor for class org.apache.openjpa.lib.log.NoneLogFactory.NoneLog
 
NoneMappingDefaults - Class in org.apache.openjpa.jdbc.meta
No-op mapping defaults.
NoneMappingDefaults() - Constructor for class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
NoneMetaDataFactory - Class in org.apache.openjpa.meta
No-op metadata I/O to prevent attempts to load other classes.
NoneMetaDataFactory() - Constructor for class org.apache.openjpa.meta.NoneMetaDataFactory
 
NoneOrphanedKeyAction - Class in org.apache.openjpa.event
Does nothing when an orphaned key is discovered.
NoneOrphanedKeyAction() - Constructor for class org.apache.openjpa.event.NoneOrphanedKeyAction
 
NoneStrategyInstaller - Class in org.apache.openjpa.jdbc.meta
Clears all mapping information from classes and installs none strategies.
NoneStrategyInstaller(MappingRepository) - Constructor for class org.apache.openjpa.jdbc.meta.NoneStrategyInstaller
Constructor; supply configuration.
NoneVersionStrategy - Class in org.apache.openjpa.jdbc.meta.strats
No-op version strategy.
NonPersistentMetaData - Class in org.apache.openjpa.meta
Metadata about a persistence-aware type.
NonPersistentMetaData(Class, MetaDataRepository, int) - Constructor for class org.apache.openjpa.meta.NonPersistentMetaData
 
Nonpolymorphic - Annotation Type in org.apache.openjpa.persistence.jdbc
Indicates that the annotated relation is not entirely polymorphic.
NonpolymorphicType - Enum in org.apache.openjpa.persistence.jdbc
Nonpolymorphic settings.
nontransactional(Object, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
nontransactional(Object, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
nontransactional(Object, OpCallbacks) - Method in interface org.apache.openjpa.kernel.StoreContext
Make the given object nontransactional.
nontransactional(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
nontransactional(Object) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Make the given object nontransactional.
nontransactionalAll(Collection, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
nontransactionalAll(Collection, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
nontransactionalAll(Collection, OpCallbacks) - Method in interface org.apache.openjpa.kernel.StoreContext
Make the given objects nontransactional.
nontransactionalAll(Collection) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
nontransactionalAll(Object[]) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
nontransactionalAll(Collection) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Make the given objects nontransactional.
nontransactionalAll(Object[]) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Make the given objects nontransactional.
nontransactionalRead - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
nontransactionalWrite - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
NonUniqueResultException - Exception in org.apache.openjpa.persistence
Unique query returned multipl results.
NonUniqueResultException(String, Throwable[], Object, boolean) - Constructor for exception org.apache.openjpa.persistence.NonUniqueResultException
 
NoResultException - Exception in org.apache.openjpa.persistence
Unique query returned no results.
NoResultException(String, Throwable[], Object, boolean) - Constructor for exception org.apache.openjpa.persistence.NoResultException
 
not(Expression) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
not(Expression) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return the inverse of this expression.
not(Expression) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
notEqual(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
notEqual(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return an expression representing the given condition.
notEqual(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
notMatches(Value, Value, String, String, String) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
notMatches(Value, Value, String, String, String) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return whether the string does not match the given pattern.
notMatches(Value, Value, String, String, String) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
NoTransactionException - Exception in org.apache.openjpa.util
Exception type thrown when attempting a transactional operation without an active transaction.
NoTransactionException(Localizer.Message) - Constructor for exception org.apache.openjpa.util.NoTransactionException
 
NULL - Static variable in class org.apache.openjpa.jdbc.kernel.exps.ExpState
State with no joins.
NULL - Static variable in class org.apache.openjpa.jdbc.meta.Discriminator
Null discriminator value marker.
NULL - Static variable in class org.apache.openjpa.jdbc.sql.RowImpl
 
NULL - Static variable in class org.apache.openjpa.kernel.AbstractPCData
 
NULL_CMP - Static variable in interface org.apache.openjpa.jdbc.kernel.exps.Val
Initialization flag indicating that this value will be compared to null.
NULL_DEFAULT - Static variable in class org.apache.openjpa.meta.FieldMetaData
Constant specifying to use a datastore default value to persist null values in object fields.
NULL_EXCEPTION - Static variable in class org.apache.openjpa.meta.FieldMetaData
Constant specifying to throw an exception when attempting to persist null values in object fields.
NULL_NONE - Static variable in class org.apache.openjpa.meta.FieldMetaData
Constant specifying to use a datastore null to persist null values in object fields.
NULL_UNSET - Static variable in class org.apache.openjpa.meta.FieldMetaData
Constant specifying that no null-value was given.
nullableAsObject - Variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool.Flags
 
nullJoins() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
nullJoins() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
nullPlusNonNullIsNull() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
nullsAreSortedAtEnd() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
nullsAreSortedAtStart() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
nullsAreSortedHigh() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
nullsAreSortedLow() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
nullTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
NUMBER - Static variable in class org.apache.openjpa.meta.JavaTypes
 
NumberVersionStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Uses a version number for optimistic versioning.
NumberVersionStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.NumberVersionStrategy
 
numericTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 

O

OBJECT - Static variable in class org.apache.openjpa.meta.JavaTypes
 
OBJECT_EXISTS - Static variable in exception org.apache.openjpa.util.StoreException
 
OBJECT_NOT_FOUND - Static variable in exception org.apache.openjpa.util.StoreException
 
objectChanged() - Method in class org.apache.openjpa.lib.conf.ObjectValue
Implement this method to synchronize internal data with the new object value.
objectChanged() - Method in class org.apache.openjpa.lib.conf.PluginListValue
 
objectChanged() - Method in class org.apache.openjpa.lib.conf.PluginValue
 
ObjectData - Class in org.apache.openjpa.xmlstore
In-memory form of data in datastore backing a single persistent object.
ObjectData(Object, ClassMetaData) - Constructor for class org.apache.openjpa.xmlstore.ObjectData
Create the object without underlying data.
ObjectExistsException - Exception in org.apache.openjpa.util
Exception type reserved for conflicts with existing objects.
ObjectExistsException(Localizer.Message) - Constructor for exception org.apache.openjpa.util.ObjectExistsException
 
ObjectId - Class in org.apache.openjpa.util
Identity type appropriate for object primary key fields and shared id classes.
ObjectId(Class, Object) - Constructor for class org.apache.openjpa.util.ObjectId
 
ObjectId(Class, Object, boolean) - Constructor for class org.apache.openjpa.util.ObjectId
 
ObjectIdClassStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Class mapping for embedded object id fields.
ObjectIdClassStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.ObjectIdClassStrategy
 
ObjectIdStateManager - Class in org.apache.openjpa.kernel
State manager used to access state of embedded object id primary key fields.
ObjectIdStateManager(Object, OpenJPAStateManager, ValueMetaData) - Constructor for class org.apache.openjpa.kernel.ObjectIdStateManager
Constructor; supply embedded object id and its owner.
ObjectIdValueHandler - Class in org.apache.openjpa.jdbc.meta.strats
Handler for embedded object id fields.
ObjectIdValueHandler() - Constructor for class org.apache.openjpa.jdbc.meta.strats.ObjectIdValueHandler
 
ObjectNotFoundException - Exception in org.apache.openjpa.util
Exception type reserved for failed object lookups.
ObjectNotFoundException(Localizer.Message) - Constructor for exception org.apache.openjpa.util.ObjectNotFoundException
 
ObjectNotFoundException(Object) - Constructor for exception org.apache.openjpa.util.ObjectNotFoundException
 
ObjectNotFoundException(Collection, Throwable[]) - Constructor for exception org.apache.openjpa.util.ObjectNotFoundException
 
ObjectValue - Class in org.apache.openjpa.lib.conf
An object Value.
ObjectValue(String) - Constructor for class org.apache.openjpa.lib.conf.ObjectValue
 
objectValueRequiresLoad(ValueMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractValueHandler
 
objectValueRequiresLoad(ValueMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.UntypedPCValueHandler
 
objectValueRequiresLoad(ValueMapping) - Method in interface org.apache.openjpa.jdbc.meta.ValueHandler
Return whether this handler potentially must load extra data to extract the object value from its datastore representation.
offer(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentLinkedQueue
Inserts the specified element at the tail of this queue.
offer(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.
OID - Static variable in class org.apache.openjpa.meta.JavaTypes
 
OID_ALLOW_NEW - Static variable in interface org.apache.openjpa.kernel.StoreContext
 
OID_COPY - Static variable in interface org.apache.openjpa.kernel.StoreContext
 
OID_NODELETED - Static variable in interface org.apache.openjpa.kernel.StoreContext
 
OID_NOVALIDATE - Static variable in interface org.apache.openjpa.kernel.StoreContext
 
onException(JMSException) - Method in class org.apache.openjpa.event.JMSRemoteCommitProvider
 
onExpire(ExpirationEvent) - Method in interface org.apache.openjpa.datacache.ExpirationListener
Notification that an object has expired from the cache.
onTypesChanged(TypesChangedEvent) - Method in class org.apache.openjpa.datacache.AbstractQueryCache
 
onTypesChanged(TypesChangedEvent) - Method in class org.apache.openjpa.datacache.DelegatingQueryCache
 
onTypesChanged(TypesChangedEvent) - Method in interface org.apache.openjpa.datacache.TypesChangedListener
Notification that instances of persistent types have changed.
OP_ATTACH - Static variable in interface org.apache.openjpa.kernel.OpCallbacks
 
OP_DELETE - Static variable in interface org.apache.openjpa.kernel.OpCallbacks
 
OP_DELETE - Static variable in interface org.apache.openjpa.kernel.QueryOperations
Symbolic constant that indicates that this query will be performing a delete operation.
OP_DETACH - Static variable in interface org.apache.openjpa.kernel.OpCallbacks
 
OP_EVICT - Static variable in interface org.apache.openjpa.kernel.OpCallbacks
 
OP_LOCK - Static variable in interface org.apache.openjpa.kernel.OpCallbacks
 
OP_NONTRANSACTIONAL - Static variable in interface org.apache.openjpa.kernel.OpCallbacks
 
OP_PERSIST - Static variable in interface org.apache.openjpa.kernel.OpCallbacks
 
OP_REFRESH - Static variable in interface org.apache.openjpa.kernel.OpCallbacks
 
OP_RELEASE - Static variable in interface org.apache.openjpa.kernel.OpCallbacks
 
OP_RETRIEVE - Static variable in interface org.apache.openjpa.kernel.OpCallbacks
 
OP_SELECT - Static variable in interface org.apache.openjpa.kernel.QueryOperations
Symbolic constant that indicates that this query will be performing a select operation.
OP_TRANSACTIONAL - Static variable in interface org.apache.openjpa.kernel.OpCallbacks
 
OP_UPDATE - Static variable in interface org.apache.openjpa.kernel.QueryOperations
Symbolic constant that indicates that this query will be performing a update operation.
OpCallbacks - Interface in org.apache.openjpa.kernel
Allows facades to control the particulars of persistence operations through callbacks.
open() - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
No-op implementation.
open() - Method in class org.apache.openjpa.jdbc.kernel.GenericResultObjectProvider
 
open() - Method in class org.apache.openjpa.jdbc.kernel.PagingResultObjectProvider
 
open() - Method in class org.apache.openjpa.jdbc.kernel.SelectResultObjectProvider
 
open() - Method in class org.apache.openjpa.kernel.AbstractPCResultObjectProvider
Override if desired.
open() - Method in class org.apache.openjpa.lib.rop.ListResultObjectProvider
 
open() - Method in class org.apache.openjpa.lib.rop.MergedResultObjectProvider
 
open() - Method in class org.apache.openjpa.lib.rop.RangeResultObjectProvider
 
open() - Method in interface org.apache.openjpa.lib.rop.ResultObjectProvider
Open the result.
open() - Method in class org.apache.openjpa.xmlstore.XMLStoreManager
 
openBrace(int) - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
openClassBrace(CodeFormat) - Method in class org.apache.openjpa.enhance.CodeGenerator
Append the opening code-level brace to the code; this can be overridden to add code to the top of the class.
OPENJPA - Static variable in class org.apache.openjpa.meta.Extensions
 
openjpa3GeneratedKeyNames - Variable in class org.apache.openjpa.jdbc.sql.OracleDictionary
Flag to use OpenJPA 0.3 style naming for auto assign sequence name and trigger name for backwards compatibility.
OpenJPAConfiguration - Interface in org.apache.openjpa.conf
Defines the properties necessary to configure runtime properties and connect to a data source.
OpenJPAConfigurationImpl - Class in org.apache.openjpa.conf
Implementation of the OpenJPAConfiguration interface.
OpenJPAConfigurationImpl() - Constructor for class org.apache.openjpa.conf.OpenJPAConfigurationImpl
Default constructor.
OpenJPAConfigurationImpl(boolean) - Constructor for class org.apache.openjpa.conf.OpenJPAConfigurationImpl
Constructor.
OpenJPAConfigurationImpl(boolean, boolean) - Constructor for class org.apache.openjpa.conf.OpenJPAConfigurationImpl
Constructor.
OpenJPAEntityManager - Interface in org.apache.openjpa.persistence
Interface implemented by OpenJPA entity managers.
OpenJPAEntityManagerFactory - Interface in org.apache.openjpa.persistence
Interface implemented by OpenJPA entity manager factories.
OpenJPAException - Exception in org.apache.openjpa.util
Exception type for all OpenJPA exceptions.
OpenJPAException() - Constructor for exception org.apache.openjpa.util.OpenJPAException
Default constructor.
OpenJPAException(String) - Constructor for exception org.apache.openjpa.util.OpenJPAException
Constructor; supply message.
OpenJPAException(Localizer.Message) - Constructor for exception org.apache.openjpa.util.OpenJPAException
Constructor; supply message.
OpenJPAException(Throwable) - Constructor for exception org.apache.openjpa.util.OpenJPAException
Construct with cause.
OpenJPAException(String, Throwable) - Constructor for exception org.apache.openjpa.util.OpenJPAException
Construct with message and cause.
OpenJPAException(Localizer.Message, Throwable) - Constructor for exception org.apache.openjpa.util.OpenJPAException
Construct with message and cause.
OpenJPAId - Class in org.apache.openjpa.util
Identity class extended by builtin OpenJPA identity objects.
OpenJPAId() - Constructor for class org.apache.openjpa.util.OpenJPAId
 
OpenJPAId(Class) - Constructor for class org.apache.openjpa.util.OpenJPAId
 
OpenJPAId(Class, boolean) - Constructor for class org.apache.openjpa.util.OpenJPAId
 
OpenJPAPersistence - Class in org.apache.openjpa.persistence
Static helper method for JPA users, including switching between OpenJPA native and Java Persistence APIs.
OpenJPAPersistence() - Constructor for class org.apache.openjpa.persistence.OpenJPAPersistence
 
OpenJPAProductDerivation - Interface in org.apache.openjpa.conf
Adds datastore based extension to ProductDerivation.
OpenJPAQuery - Interface in org.apache.openjpa.persistence
Interface implemented by OpenJPA queries.
OpenJPASavepoint - Class in org.apache.openjpa.kernel
Represents a savepoint where operations afterwards can be rolled back and restored to this point
OpenJPASavepoint(Broker, String, boolean) - Constructor for class org.apache.openjpa.kernel.OpenJPASavepoint
Constructor.
OpenJPAStateManager - Interface in org.apache.openjpa.kernel
Interface implemented by OpenJPA state managers.
openjpaTables - Variable in class org.apache.openjpa.jdbc.meta.MappingTool.Flags
 
openjpaTables - Variable in class org.apache.openjpa.jdbc.schema.SchemaTool.Flags
 
OpenJPAVersion - Class in org.apache.openjpa.conf
This class contains version information for OpenJPA.
OpenJPAVersion() - Constructor for class org.apache.openjpa.conf.OpenJPAVersion
 
openParen(boolean) - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
operation - Variable in class org.apache.openjpa.kernel.exps.QueryExpressions
 
OperationOrderUpdateManager - Class in org.apache.openjpa.jdbc.kernel
Update manager that writes SQL in object-level operation order.
OperationOrderUpdateManager() - Constructor for class org.apache.openjpa.jdbc.kernel.OperationOrderUpdateManager
 
optimistic - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
OPTIMISTIC - Static variable in exception org.apache.openjpa.util.StoreException
 
OptimisticException - Exception in org.apache.openjpa.util
Exception type for optimistic concurrency violations.
OptimisticException(Localizer.Message) - Constructor for exception org.apache.openjpa.util.OptimisticException
 
OptimisticException(Object) - Constructor for exception org.apache.openjpa.util.OptimisticException
 
OptimisticException(Throwable[]) - Constructor for exception org.apache.openjpa.util.OptimisticException
 
OptimisticException(Collection, Throwable[]) - Constructor for exception org.apache.openjpa.util.OptimisticException
 
OptimisticLockException - Exception in org.apache.openjpa.persistence
Optimistic concurrency violation.
OptimisticLockException(String, Throwable[], Object, boolean) - Constructor for exception org.apache.openjpa.persistence.OptimisticLockException
 
OPTION_DATASTORE_CONNECTION - Static variable in interface org.apache.openjpa.conf.OpenJPAConfiguration
Option for runtimes that support returning the datastore connection.
OPTION_EMBEDDED_COLLECTION_RELATION - Static variable in interface org.apache.openjpa.conf.OpenJPAConfiguration
Option for runtimes that support collections of embedded relations to other persistence capable objects.
OPTION_EMBEDDED_MAP_RELATION - Static variable in interface org.apache.openjpa.conf.OpenJPAConfiguration
Option for runtimes that support maps of embedded relations to other persistence capable objects.
OPTION_EMBEDDED_RELATION - Static variable in interface org.apache.openjpa.conf.OpenJPAConfiguration
Option for runtimes that support embedded relations to other persistence capable objects.
OPTION_ID_APPLICATION - Static variable in interface org.apache.openjpa.conf.OpenJPAConfiguration
Option for runtimes that support application identity.
OPTION_ID_DATASTORE - Static variable in interface org.apache.openjpa.conf.OpenJPAConfiguration
Option for runtimes that support application identity.
OPTION_INC_FLUSH - Static variable in interface org.apache.openjpa.conf.OpenJPAConfiguration
Option for runtimes that support incremental flushing.
OPTION_JDBC_CONNECTION - Static variable in interface org.apache.openjpa.conf.OpenJPAConfiguration
Option for runtimes that support returning the datastore connection that is a JDBC Connection.
OPTION_NONTRANS_READ - Static variable in interface org.apache.openjpa.conf.OpenJPAConfiguration
Option for runtimes that support nontransactional reads.
OPTION_NULL_CONTAINER - Static variable in interface org.apache.openjpa.conf.OpenJPAConfiguration
Option for runtime that can differentiate between null and empty container fields.
OPTION_OPTIMISTIC - Static variable in interface org.apache.openjpa.conf.OpenJPAConfiguration
Option for runtimes that support optimistic transactions.
OPTION_QUERY_SQL - Static variable in interface org.apache.openjpa.conf.OpenJPAConfiguration
Option for SQL support.
OPTION_TYPE_ARRAY - Static variable in interface org.apache.openjpa.conf.OpenJPAConfiguration
Option for runtimes that support persistent array fields.
OPTION_TYPE_COLLECTION - Static variable in interface org.apache.openjpa.conf.OpenJPAConfiguration
Option for runtimes that support persistent collection fields.
OPTION_TYPE_MAP - Static variable in interface org.apache.openjpa.conf.OpenJPAConfiguration
Option for runtimes that support persistent map fields.
OPTION_VALUE_AUTOASSIGN - Static variable in interface org.apache.openjpa.conf.OpenJPAConfiguration
Option for runtimes that the autoassign value strategy.
OPTION_VALUE_INCREMENT - Static variable in interface org.apache.openjpa.conf.OpenJPAConfiguration
Option for runtimes that the increment value strategy.
Options - Class in org.apache.openjpa.lib.util
A specialization of the Properties map type with the added abilities to read application options from the command line and to use bean patterns to set an object's properties via command-line the stored mappings.
Options() - Constructor for class org.apache.openjpa.lib.util.Options
Default constructor.
Options(Properties) - Constructor for class org.apache.openjpa.lib.util.Options
Construct the options instance with the given set of defaults.
or(Expression, Expression) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
or(Joins, Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
or(Joins, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
OR the given joins together.
or(Joins, Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
or(Expression, Expression) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return the two expressions OR'd together.
or(Expression, Expression) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
OracleDictionary - Class in org.apache.openjpa.jdbc.sql
Dictionary for Oracle.
OracleDictionary() - Constructor for class org.apache.openjpa.jdbc.sql.OracleDictionary
 
order(QueryExpressions, List, StoreContext, Object[]) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
Order the given list of matches on the given value.
order(Object) - Method in class org.apache.openjpa.meta.FieldMetaData
Order this field value when it is loaded.
Order - Interface in org.apache.openjpa.meta
Order a field.
orderBy(Select, ExpContext, ExpState, boolean) - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
 
orderBy(Select, ExpContext, ExpState, boolean) - Method in interface org.apache.openjpa.jdbc.kernel.exps.Val
Order by this value.
orderBy(Column, boolean, boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
orderBy(Column, boolean, Joins, boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
orderBy(Column[], boolean, boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
orderBy(Column[], boolean, Joins, boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
orderBy(SQLBuffer, boolean, boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
orderBy(SQLBuffer, boolean, Joins, boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
orderBy(String, boolean, boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
orderBy(String, boolean, Joins, boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
orderBy(Column, boolean, boolean) - Method in interface org.apache.openjpa.jdbc.sql.Select
Order by the given column.
orderBy(Column, boolean, Joins, boolean) - Method in interface org.apache.openjpa.jdbc.sql.Select
Order by the given column.
orderBy(Column[], boolean, boolean) - Method in interface org.apache.openjpa.jdbc.sql.Select
Order by the given columns.
orderBy(Column[], boolean, Joins, boolean) - Method in interface org.apache.openjpa.jdbc.sql.Select
Order by the given columns.
orderBy(SQLBuffer, boolean, boolean) - Method in interface org.apache.openjpa.jdbc.sql.Select
Add an ORDER BY clause.
orderBy(SQLBuffer, boolean, Joins, boolean) - Method in interface org.apache.openjpa.jdbc.sql.Select
Add an ORDER BY clause.
orderBy(String, boolean, boolean) - Method in interface org.apache.openjpa.jdbc.sql.Select
Add an ORDER BY clause.
orderBy(String, boolean, Joins, boolean) - Method in interface org.apache.openjpa.jdbc.sql.Select
Add an ORDER BY clause.
orderBy(Column, boolean, boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
orderBy(Column, boolean, Joins, boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
orderBy(Column[], boolean, boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
orderBy(Column[], boolean, Joins, boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
orderBy(SQLBuffer, boolean, boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
orderBy(SQLBuffer, boolean, Joins, boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
orderBy(String, boolean, boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
orderBy(String, boolean, Joins, boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
orderByPrimaryKey(ClassMapping, boolean, boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
orderByPrimaryKey(ClassMapping, boolean, Joins, boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
orderByPrimaryKey(ClassMapping, boolean, boolean) - Method in interface org.apache.openjpa.jdbc.sql.Select
Order on the primary key columns of the given mapping, joining to superclasses as necessary to get all columns needed to construct an object id.
orderByPrimaryKey(ClassMapping, boolean, Joins, boolean) - Method in interface org.apache.openjpa.jdbc.sql.Select
Select and order on the primary key columns of the given mapping, joining to superclasses as necessary to get all columns needed to construct an object id.
orderByPrimaryKey(ClassMapping, boolean, boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
orderByPrimaryKey(ClassMapping, boolean, Joins, boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
orderByPrimaryKey(ClassMapping, boolean, Joins, boolean, boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
Allow unions to set aliases on order columns.
OrderColumn - Annotation Type in org.apache.openjpa.persistence.jdbc
Surrogate order column.
orderDirty() - Method in class org.apache.openjpa.jdbc.kernel.OperationOrderUpdateManager
 
orderDirty() - Method in interface org.apache.openjpa.jdbc.kernel.UpdateManager
Whether the store context should maintain the order in which instances are dirtied.
orderIdxs - Variable in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
ordering - Variable in class org.apache.openjpa.jdbc.kernel.exps.QueryExpressionsState
 
ordering - Variable in class org.apache.openjpa.kernel.exps.QueryExpressions
 
orderingClauses - Variable in class org.apache.openjpa.kernel.exps.QueryExpressions
 
OrderingMergedResultObjectProvider - Class in org.apache.openjpa.kernel
Merged result object provider specialization that extracts ordering values from results for comparison.
OrderingMergedResultObjectProvider(ResultObjectProvider[], boolean[], StoreQuery.Executor, StoreQuery, Object[]) - Constructor for class org.apache.openjpa.kernel.OrderingMergedResultObjectProvider
 
OrderingMergedResultObjectProvider(ResultObjectProvider[], boolean[], StoreQuery.Executor[], StoreQuery, Object[]) - Constructor for class org.apache.openjpa.kernel.OrderingMergedResultObjectProvider
 
orderLocal(Select, ClassMapping, Joins) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Add ordering to the given select for all non-relation order values, including the synthetic order column, if any.
orderRelation(Select, ClassMapping, Joins) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Add ordering to the given select for all relation-based values.
orders - Variable in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
org.apache.openjpa.abstractstore - package org.apache.openjpa.abstractstore
OpenJPA Abstract StoreManager Implementation
org.apache.openjpa.ant - package org.apache.openjpa.ant
OpenJPA Ant Tasks
org.apache.openjpa.conf - package org.apache.openjpa.conf
OpenJPA Configuration
org.apache.openjpa.datacache - package org.apache.openjpa.datacache
OpenJPA Data Cache
org.apache.openjpa.ee - package org.apache.openjpa.ee
OpenJPA Enterprise Extensions
org.apache.openjpa.enhance - package org.apache.openjpa.enhance
OpenJPA Enhancer
org.apache.openjpa.event - package org.apache.openjpa.event
OpenJPA Events
org.apache.openjpa.jdbc.ant - package org.apache.openjpa.jdbc.ant
OpenJPA-JDBC Ant Tasks
org.apache.openjpa.jdbc.conf - package org.apache.openjpa.jdbc.conf
OpenJPA-JDBC Configuration
org.apache.openjpa.jdbc.kernel - package org.apache.openjpa.jdbc.kernel
OpenJPA-JDBC Runtime Kernel
org.apache.openjpa.jdbc.kernel.exps - package org.apache.openjpa.jdbc.kernel.exps
OpenJPA-JDBC Expression Tree
org.apache.openjpa.jdbc.meta - package org.apache.openjpa.jdbc.meta
OpenJPA-JDBC ORM Metadata
org.apache.openjpa.jdbc.meta.strats - package org.apache.openjpa.jdbc.meta.strats
OpenJPA-JDBC ORM Strategies
org.apache.openjpa.jdbc.schema - package org.apache.openjpa.jdbc.schema
OpenJPA-JDBC Schema Management
org.apache.openjpa.jdbc.sql - package org.apache.openjpa.jdbc.sql
OpenJPA-JDBC SQL Abstraction
org.apache.openjpa.kernel - package org.apache.openjpa.kernel
OpenJPA Runtime Kernel
org.apache.openjpa.kernel.exps - package org.apache.openjpa.kernel.exps
OpenJPA Expression Tree
org.apache.openjpa.kernel.jpql - package org.apache.openjpa.kernel.jpql
JPA Query Language Support
org.apache.openjpa.lib.ant - package org.apache.openjpa.lib.ant
Ant Integration
org.apache.openjpa.lib.conf - package org.apache.openjpa.lib.conf
Configuration Framework
org.apache.openjpa.lib.jdbc - package org.apache.openjpa.lib.jdbc
Database Connectivity
org.apache.openjpa.lib.log - package org.apache.openjpa.lib.log
Logging
org.apache.openjpa.lib.meta - package org.apache.openjpa.lib.meta
Metadata Framework
org.apache.openjpa.lib.rop - package org.apache.openjpa.lib.rop
Result Object Provider Framework
org.apache.openjpa.lib.util - package org.apache.openjpa.lib.util
General Utilities
org.apache.openjpa.lib.util.concurrent - package org.apache.openjpa.lib.util.concurrent
Concurrent Utilities
org.apache.openjpa.lib.xml - package org.apache.openjpa.lib.xml
XML Handling
org.apache.openjpa.meta - package org.apache.openjpa.meta
OpenJPA Metadata
org.apache.openjpa.persistence - package org.apache.openjpa.persistence
OpenJPA JPA
org.apache.openjpa.persistence.jdbc - package org.apache.openjpa.persistence.jdbc
OpenJPA JPA-JDBC
org.apache.openjpa.util - package org.apache.openjpa.util
OpenJPA Utilities
org.apache.openjpa.xmlstore - package org.apache.openjpa.xmlstore
XML Store
orphan(Object, OpenJPAStateManager, ValueMetaData) - Method in class org.apache.openjpa.event.ExceptionOrphanedKeyAction
 
orphan(Object, OpenJPAStateManager, ValueMetaData) - Method in class org.apache.openjpa.event.LogOrphanedKeyAction
 
orphan(Object, OpenJPAStateManager, ValueMetaData) - Method in class org.apache.openjpa.event.NoneOrphanedKeyAction
 
orphan(Object, OpenJPAStateManager, ValueMetaData) - Method in interface org.apache.openjpa.event.OrphanedKeyAction
Callback received when OpenJPA discovers an orphaned key.
OrphanedKeyAction - Interface in org.apache.openjpa.event
Perform an action when OpenJPA detects an orphaned key in the database.
orphanedKeyPlugin - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
othersDeletesAreVisible(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
othersInsertsAreVisible(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
othersUpdatesAreVisible(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
otherTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
outer(Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
outer(Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
Return a join set making the given joins outer joins.
outer(Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
outerJoin(ForeignKey, boolean, boolean) - Method in interface org.apache.openjpa.jdbc.sql.Joins
Join the columns of the given foreign key.
outerJoin(ForeignKey, boolean, boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
outerJoin(ForeignKey, boolean, boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
outerJoinClause - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
outerJoinRelation(String, ForeignKey, ClassMapping, int, boolean, boolean) - Method in interface org.apache.openjpa.jdbc.sql.Joins
Join the columns of the given foreign key, which represents a relation via the given field name.
outerJoinRelation(String, ForeignKey, ClassMapping, int, boolean, boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
outerJoinRelation(String, ForeignKey, ClassMapping, int, boolean, boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
overflowRemoved(Object, Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
 
overflowRemoved(Object, Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
 
overflowRemoved(Object, Object) - Method in class org.apache.openjpa.lib.util.LRUMap
 
overflowRemoved(Object, Object) - Method in class org.apache.openjpa.lib.util.ReferenceHashMap
 
overflowRemoved(Object, Object) - Method in interface org.apache.openjpa.lib.util.SizedMap
Overridable callback for when an overflow entry is automatically removed.
ownDeletesAreVisible(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
ownInsertsAreVisible(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
ownUpdatesAreVisible(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 

P

pack(Object) - Method in class org.apache.openjpa.kernel.ResultPacker
Pack the given object into an instance of the query's result class.
pack(Object[]) - Method in class org.apache.openjpa.kernel.ResultPacker
Pack the given array into an instance of the query's result class.
packageName - Variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool.Flags
 
PagingResultObjectProvider - Class in org.apache.openjpa.jdbc.kernel
Object provider implementation that fetches one page of results at a a time as it scrolls.
PagingResultObjectProvider(SelectExecutor, ClassMapping, JDBCStore, JDBCFetchConfiguration, BitSet, long) - Constructor for class org.apache.openjpa.jdbc.kernel.PagingResultObjectProvider
Constructor.
PagingResultObjectProvider(SelectExecutor, ClassMapping[], JDBCStore, JDBCFetchConfiguration, BitSet[], long) - Constructor for class org.apache.openjpa.jdbc.kernel.PagingResultObjectProvider
Constructor.
Parameter - Interface in org.apache.openjpa.kernel.exps
A query parameter.
ParameterTemplate - Class in org.apache.openjpa.lib.util
A template that allows parameter substitutions.
ParameterTemplate() - Constructor for class org.apache.openjpa.lib.util.ParameterTemplate
 
parameterTypes - Variable in class org.apache.openjpa.kernel.exps.QueryExpressions
 
params - Variable in class org.apache.openjpa.jdbc.kernel.exps.ExpContext
Parameters to query.
parens() - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
parse(String, ExpressionStoreQuery) - Method in interface org.apache.openjpa.kernel.exps.ExpressionParser
Return a parsed intermediate form of the given query string.
parse(String, ExpressionStoreQuery) - Method in class org.apache.openjpa.kernel.jpql.JPQLParser
 
parse(String) - Method in interface org.apache.openjpa.lib.meta.MetaDataParser
Parse the given resource.
parse(URL) - Method in interface org.apache.openjpa.lib.meta.MetaDataParser
Parse the given resource.
parse(File) - Method in interface org.apache.openjpa.lib.meta.MetaDataParser
Parse the given file, which may be a directory, in which case it will be scanned recursively for metadata files.
parse(Class, boolean) - Method in interface org.apache.openjpa.lib.meta.MetaDataParser
Parse all possible metadata locations for the given class, going top-down or bottom-up.
parse(Reader, String) - Method in interface org.apache.openjpa.lib.meta.MetaDataParser
Parse the metadata in the given reader.
parse(MetaDataIterator) - Method in interface org.apache.openjpa.lib.meta.MetaDataParser
Parse the metadata supplied by the given iterator.
parse(String) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
 
parse(URL) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
 
parse(File) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
 
parse(Class, boolean) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
 
parse(Reader, String) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
 
parse(MetaDataIterator) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
 
parse(MetaDataParser, Collection) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Parse all given files.
parse(MetaDataParser, Class[]) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Parse all given classses.
parse(Class) - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Parse persistence metadata for the given class.
parse(MetaDataParser, Class[]) - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
 
parseBasic(FieldMetaData, Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Parse basic.
parseCallbackMethods(Class, Collection<LifecycleCallbacks>[], boolean, boolean, MetaDataRepository) - Static method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Parse callback methods into the given array, and return that array, creating one if null.
parseClassMappingAnnotations(ClassMetaData) - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Parse class mapping annotations.
parseClassMappingAnnotations(ClassMetaData) - Method in class org.apache.openjpa.persistence.jdbc.AnnotationPersistenceMappingParser
 
parseColumns(FieldMapping, Column...) - Method in class org.apache.openjpa.persistence.jdbc.AnnotationPersistenceMappingParser
Parse @Column(s).
parseContainerTable(FieldMapping, ContainerTable) - Method in class org.apache.openjpa.persistence.jdbc.AnnotationPersistenceMappingParser
Parse @ContainerTable.
parsed(String) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Return true if the given source is parsed.
parseDeclaration(String, char, String) - Static method in class org.apache.openjpa.kernel.Filters
Parses the given declarations into a list of type, name, type, name...
parseElementJoinColumns(FieldMapping, ElementJoinColumn...) - Method in class org.apache.openjpa.persistence.jdbc.AnnotationPersistenceMappingParser
Parse @ElementJoinColumn(s).
parseEmbedded(FieldMetaData, Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Parse embedded.
parseException(int, String, Object[], Exception) - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
Create a proper parse exception for the given reason.
ParseException - Exception in org.apache.openjpa.kernel.jpql
Signifies that a lexical error occurred when parsing the JPQL statement.
ParseException(Token, int[][], String[]) - Constructor for exception org.apache.openjpa.kernel.jpql.ParseException
This constructor is used by the method "generateParseException" in the generated parser.
ParseException() - Constructor for exception org.apache.openjpa.kernel.jpql.ParseException
The following constructors are for use by you for whatever purpose you can think of.
ParseException - Exception in org.apache.openjpa.lib.util
Exception type for parse errors.
ParseException() - Constructor for exception org.apache.openjpa.lib.util.ParseException
 
ParseException(String) - Constructor for exception org.apache.openjpa.lib.util.ParseException
 
ParseException(Localizer.Message) - Constructor for exception org.apache.openjpa.lib.util.ParseException
 
ParseException(Throwable) - Constructor for exception org.apache.openjpa.lib.util.ParseException
 
ParseException(String, Throwable) - Constructor for exception org.apache.openjpa.lib.util.ParseException
 
ParseException(Localizer.Message, Throwable) - Constructor for exception org.apache.openjpa.lib.util.ParseException
 
parseForeignKey(MappingInfo, String, boolean, boolean, ForeignKeyAction, ForeignKeyAction) - Method in class org.apache.openjpa.persistence.jdbc.AnnotationPersistenceMappingParser
Set foreign key data on the given mapping info.
parseIndex(MappingInfo, String, boolean, boolean) - Method in class org.apache.openjpa.persistence.jdbc.AnnotationPersistenceMappingParser
Set index data on the given mapping info.
parseLobMapping(FieldMetaData) - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Setup the field as a LOB mapping.
parseLobMapping(FieldMetaData) - Method in class org.apache.openjpa.persistence.jdbc.AnnotationPersistenceMappingParser
 
parseManyToMany(FieldMetaData, Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Parse many-to-many.
parseManyToOne(FieldMetaData, Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Parse many-to-one.
parseMemberMappingAnnotations(FieldMetaData) - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Parse member mapping components.
parseMemberMappingAnnotations(FieldMetaData) - Method in class org.apache.openjpa.persistence.jdbc.AnnotationPersistenceMappingParser
 
parseNewResource(Reader, String) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Parse a previously-unseen source.
parseOneToMany(FieldMetaData, Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Parse one-to-many.
parseOneToOne(FieldMetaData, Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Parse one-to-one.
parsePackageMappingAnnotations(Package) - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Parse package mapping annotations.
parsePackageMappingAnnotations(Package) - Method in class org.apache.openjpa.persistence.jdbc.AnnotationPersistenceMappingParser
 
parseProperties(String) - Static method in class org.apache.openjpa.lib.conf.Configurations
Parse a set of properties from a comma-separated string.
parserForLanguage(String) - Static method in class org.apache.openjpa.kernel.QueryLanguages
Return the ExpressionParser for language, or null if no expression parser exists in the system for the specified language.
parseTypeNames(String) - Method in class org.apache.openjpa.lib.meta.ClassArgParser
Return the names of the class(es) from the given arg.
parseTypeNames(MetaDataIterator) - Method in class org.apache.openjpa.lib.meta.ClassArgParser
Return the names of the class(es) from the given metadatas.
parseTypes(String) - Method in class org.apache.openjpa.lib.meta.ClassArgParser
Return the Class representation of the class(es) named in the given arg.
parseTypes(MetaDataIterator) - Method in class org.apache.openjpa.lib.meta.ClassArgParser
Return the Class representation of the class(es) named in the given metadatas.
parseXJoinColumns(FieldMapping, MappingInfo, boolean, XJoinColumn...) - Method in class org.apache.openjpa.persistence.jdbc.AnnotationPersistenceMappingParser
Parse given @XJoinColumn annotations.
PAST_END - Static variable in class org.apache.openjpa.lib.rop.AbstractNonSequentialResultList
 
PATCH_RELEASE - Static variable in class org.apache.openjpa.conf.OpenJPAVersion
 
path() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
path() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
Path - Interface in org.apache.openjpa.kernel.exps
A path represents a traversal into fields of a candidate object.
PAYLOAD_EXTENTS - Static variable in class org.apache.openjpa.event.RemoteCommitEvent
Names of added, updated, and deleted classes only.
PAYLOAD_OIDS - Static variable in class org.apache.openjpa.event.RemoteCommitEvent
Names of added classes, upated and deleted Object IDs.
PAYLOAD_OIDS_WITH_ADDS - Static variable in class org.apache.openjpa.event.RemoteCommitEvent
Names of added classes, added, upated and deleted Object IDs.
PC - Static variable in class org.apache.openjpa.meta.JavaTypes
 
PC_UNTYPED - Static variable in class org.apache.openjpa.meta.JavaTypes
 
PCClassFileTransformer - Class in org.apache.openjpa.enhance
Transformer that makes persistent classes implement the PersistenceCapable interface at runtime.
PCClassFileTransformer(MetaDataRepository, Options, ClassLoader) - Constructor for class org.apache.openjpa.enhance.PCClassFileTransformer
Constructor.
PCClassFileTransformer(MetaDataRepository, PCEnhancer.Flags, ClassLoader, boolean) - Constructor for class org.apache.openjpa.enhance.PCClassFileTransformer
Constructor.
pcCopyFields(Object, int[]) - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
pcCopyKeyFieldsFromObjectId(FieldConsumer, Object) - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
pcCopyKeyFieldsToObjectId(Object) - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
pcCopyKeyFieldsToObjectId(FieldSupplier, Object) - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
PCData - Interface in org.apache.openjpa.kernel
Holds data about a single persistence capable instance.
PCDataGenerator - Class in org.apache.openjpa.enhance
Generates PCDataGenerator.DynamicPCData instances which avoid primitve wrappers to optimize memory use and performance at the cost of slightly higher startup time.
PCDataGenerator(OpenJPAConfiguration) - Constructor for class org.apache.openjpa.enhance.PCDataGenerator
 
PCDataGenerator.DynamicPCData - Interface in org.apache.openjpa.enhance
Dynamic PCDatas generated will implement this interface to simplify initialization.
PCDataImpl - Class in org.apache.openjpa.kernel
Default PCData implementation.
PCDataImpl(Object, ClassMetaData) - Constructor for class org.apache.openjpa.kernel.PCDataImpl
Constructor.
pcDirty(String) - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
PCEnhancer - Class in org.apache.openjpa.enhance
Bytecode enhancer used to enhance persistent classes from metadata.
PCEnhancer(OpenJPAConfiguration, Class) - Constructor for class org.apache.openjpa.enhance.PCEnhancer
Constructor.
PCEnhancer(OpenJPAConfiguration, ClassMetaData) - Constructor for class org.apache.openjpa.enhance.PCEnhancer
Constructor.
PCEnhancer(OpenJPAConfiguration, BCClass, MetaDataRepository) - Constructor for class org.apache.openjpa.enhance.PCEnhancer
Constructor.
PCEnhancer(OpenJPAConfiguration, BCClass, ClassMetaData) - Constructor for class org.apache.openjpa.enhance.PCEnhancer
Constructor.
PCEnhancer.AuxiliaryEnhancer - Interface in org.apache.openjpa.enhance
Plugin interface for additional enhancement.
PCEnhancer.Flags - Class in org.apache.openjpa.enhance
Run flags.
PCEnhancer.Flags() - Constructor for class org.apache.openjpa.enhance.PCEnhancer.Flags
 
PCEnhancerAgent - Class in org.apache.openjpa.enhance
Java agent that makes persistent classes implement the PersistenceCapable interface at runtime.
PCEnhancerAgent() - Constructor for class org.apache.openjpa.enhance.PCEnhancerAgent
 
PCEnhancerTask - Class in org.apache.openjpa.ant
Executes the enhancer on the specified files.
PCEnhancerTask() - Constructor for class org.apache.openjpa.ant.PCEnhancerTask
 
pcFetchObjectId() - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
pcGetDetachedState() - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
pcGetGenericContext() - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
pcGetStateManager() - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
pcGetVersion() - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
pcIsDeleted() - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
pcIsDetached() - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
pcIsDirty() - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
pcIsNew() - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
pcIsPersistent() - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
pcIsTransactional() - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
PCLEAN - Static variable in class org.apache.openjpa.kernel.PCState
Persistent-Clean
pcNewInstance(StateManager, boolean) - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
pcNewInstance(StateManager, Object, boolean) - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
pcNewObjectIdInstance() - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
pcNewObjectIdInstance(Object) - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
pcProvideField(int) - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
pcProvideFields(int[]) - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
PCRegistry - Class in org.apache.openjpa.enhance
Tracks registered persistence-capable classes.
PCRegistry() - Constructor for class org.apache.openjpa.enhance.PCRegistry
 
PCRegistry.RegisterClassListener - Interface in org.apache.openjpa.enhance
Listener for persistent class registration events.
pcReplaceField(int) - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
pcReplaceFields(int[]) - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
pcReplaceFlags() - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
pcReplaceStateManager(StateManager) - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
PCResultObjectProvider - Interface in org.apache.openjpa.kernel
Variant of ResultObjectProvider that populates a OpenJPAStateManager object in an application-defined manner.
pcSetDetachedState(Object) - Method in interface org.apache.openjpa.enhance.PersistenceCapable
 
PCState - Class in org.apache.openjpa.kernel
Base class for all lifecycle states.
PCState() - Constructor for class org.apache.openjpa.kernel.PCState
 
PDELETED - Static variable in class org.apache.openjpa.kernel.PCState
Persistent-Deleted
PDELETEDFLUSHED - Static variable in class org.apache.openjpa.kernel.PCState
Persistent-Deleted-Flushed
PDIRTY - Static variable in class org.apache.openjpa.kernel.PCState
Persistent-Dirty
peek() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentLinkedQueue
 
peek() - Method in interface org.apache.openjpa.lib.util.concurrent.Queue
Retrieves, but does not remove, the head of this queue, or returns null if this queue is empty.
persist(Object, OpCallbacks) - Method in interface org.apache.openjpa.kernel.Broker
Persist the given object.
persist(Object, Object, OpCallbacks) - Method in interface org.apache.openjpa.kernel.Broker
Make the given instance persistent.
persist(Object, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
persist(Object, Object, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
persist(Object, boolean, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
Persist the given object.
persist(Object, Object, boolean, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
Persist the given object.
persist(Object, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
persist(Object, Object, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
persist(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
persistAll(Collection, OpCallbacks) - Method in interface org.apache.openjpa.kernel.Broker
Persist the given objects.
persistAll(Collection, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
persistAll(Collection, boolean, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
Persist the given objects.
persistAll(Collection, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
persistAll(Object...) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
persistAll(Collection) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
persistAll(Object...) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Persist the given objects.
persistAll(Collection) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Persist the given objects.
PersistenceCapable - Interface in org.apache.openjpa.enhance
The interface that persistent instances will implement.
PersistenceException - Exception in org.apache.openjpa.persistence
General persistence exception.
PersistenceException(String, Throwable[], Object, boolean) - Constructor for exception org.apache.openjpa.persistence.PersistenceException
 
PersistenceExceptions - Class in org.apache.openjpa.persistence
Converts from OpenJPA to persistence exception types.
PersistenceExceptions() - Constructor for class org.apache.openjpa.persistence.PersistenceExceptions
 
PersistenceMappingDefaults - Class in org.apache.openjpa.persistence.jdbc
Supplies default mapping information in accordance with JPA spec.
PersistenceMappingDefaults() - Constructor for class org.apache.openjpa.persistence.jdbc.PersistenceMappingDefaults
 
PersistenceMappingFactory - Class in org.apache.openjpa.persistence.jdbc
MetaDataFactory for JPA mapping information.
PersistenceMappingFactory() - Constructor for class org.apache.openjpa.persistence.jdbc.PersistenceMappingFactory
 
PersistenceMetaDataDefaults - Class in org.apache.openjpa.persistence
JPA-based metadata defaults.
PersistenceMetaDataDefaults() - Constructor for class org.apache.openjpa.persistence.PersistenceMetaDataDefaults
 
PersistenceMetaDataFactory - Class in org.apache.openjpa.persistence
MetaDataFactory for JPA metadata.
PersistenceMetaDataFactory() - Constructor for class org.apache.openjpa.persistence.PersistenceMetaDataFactory
 
PersistenceProductDerivation - Class in org.apache.openjpa.persistence
Sets JPA specification defaults and parses JPA specification XML files.
PersistenceProductDerivation() - Constructor for class org.apache.openjpa.persistence.PersistenceProductDerivation
 
PersistenceProductDerivation.ConfigurationProviderImpl - Class in org.apache.openjpa.persistence
Custom configuration provider.
PersistenceProductDerivation.ConfigurationProviderImpl() - Constructor for class org.apache.openjpa.persistence.PersistenceProductDerivation.ConfigurationProviderImpl
 
PersistenceProductDerivation.ConfigurationProviderImpl(Map) - Constructor for class org.apache.openjpa.persistence.PersistenceProductDerivation.ConfigurationProviderImpl
 
PersistenceProviderImpl - Class in org.apache.openjpa.persistence
Bootstrapping class that allows the creation of a stand-alone EntityManager.
PersistenceProviderImpl() - Constructor for class org.apache.openjpa.persistence.PersistenceProviderImpl
 
PersistenceStrategy - Enum in org.apache.openjpa.persistence
Set of field persistence strategies used in JPA.
PersistenceUnitInfoImpl - Class in org.apache.openjpa.persistence
Implementation of the PersistenceUnitInfo interface used by OpenJPA when parsing persistence configuration information.
PersistenceUnitInfoImpl() - Constructor for class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
Persistent - Annotation Type in org.apache.openjpa.persistence
Metadata annotation for a persistent field.
PersistentCollection - Annotation Type in org.apache.openjpa.persistence
Metadata annotation for a persistent collection field.
PersistentMap - Annotation Type in org.apache.openjpa.persistence
Metadata annotation for a persistent map field.
PersistListener - Interface in org.apache.openjpa.event
Listener for newly-persisted instances.
PessimisticLockManager - Class in org.apache.openjpa.jdbc.kernel
Lock manager that uses exclusive database locks.
PessimisticLockManager() - Constructor for class org.apache.openjpa.jdbc.kernel.PessimisticLockManager
 
pin(Object) - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
pin(QueryKey) - Method in class org.apache.openjpa.datacache.AbstractQueryCache
 
pin(Object) - Method in interface org.apache.openjpa.datacache.DataCache
Pin the value stored under oid into the cache.
pin(Object) - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
pin(QueryKey) - Method in class org.apache.openjpa.datacache.DelegatingQueryCache
 
pin(QueryKey) - Method in interface org.apache.openjpa.datacache.QueryCache
Pin the value stored under qk into the cache.
pin(Query) - Method in interface org.apache.openjpa.persistence.QueryResultCache
Pin the given query's result to the cache.
pin(Query) - Method in class org.apache.openjpa.persistence.QueryResultCacheImpl
 
pin(Class, Object) - Method in interface org.apache.openjpa.persistence.StoreCache
Pin the data for the given oid to the cache.
pin(Class, Object) - Method in class org.apache.openjpa.persistence.StoreCacheImpl
 
pin(Object) - Method in class org.apache.openjpa.util.CacheMap
Locks the given key and its value into the map.
pinAll(Collection) - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
pinAll(Class, boolean) - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
pinAll(Collection) - Method in interface org.apache.openjpa.datacache.DataCache
Pin all oids to the cache.
pinAll(Class, boolean) - Method in interface org.apache.openjpa.datacache.DataCache
Pin all oids for the given type.
pinAll(Collection) - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
pinAll(Class, boolean) - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
pinAll(Class, Object...) - Method in interface org.apache.openjpa.persistence.StoreCache
Pin the data for the given oids to the cache.
pinAll(Class, Collection) - Method in interface org.apache.openjpa.persistence.StoreCache
Pin the data for the given oids to the cache.
pinAll(Class, Object...) - Method in class org.apache.openjpa.persistence.StoreCacheImpl
 
pinAll(Class, Collection) - Method in class org.apache.openjpa.persistence.StoreCacheImpl
 
pinInternal(Object) - Method in class org.apache.openjpa.datacache.AbstractDataCache
Pin an object to the cache.
pinInternal(QueryKey) - Method in class org.apache.openjpa.datacache.AbstractQueryCache
Pin an object to the cache.
pinInternal(Object) - Method in class org.apache.openjpa.datacache.ConcurrentDataCache
 
pinInternal(QueryKey) - Method in class org.apache.openjpa.datacache.ConcurrentQueryCache
 
pinnedMap - Variable in class org.apache.openjpa.util.CacheMap
The set of objects pinned into the cache.
PK_VALUE - Static variable in class org.apache.openjpa.jdbc.kernel.ValueTableJDBCSeq
 
platform - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
PluginListValue - Class in org.apache.openjpa.lib.conf
A list of plugins.
PluginListValue(String) - Constructor for class org.apache.openjpa.lib.conf.PluginListValue
 
PluginValue - Class in org.apache.openjpa.lib.conf
A plugin Value consisting of plugin name and properties.
PluginValue(String, boolean) - Constructor for class org.apache.openjpa.lib.conf.PluginValue
 
PNEW - Static variable in class org.apache.openjpa.kernel.PCState
Persistent-New
PNEWDELETED - Static variable in class org.apache.openjpa.kernel.PCState
Persistent-New-Deleted
PNEWFLUSHEDDELETED - Static variable in class org.apache.openjpa.kernel.PCState
Persistent-New-Flushed-Deleted
PNEWFLUSHEDDELETEDFLUSHED - Static variable in class org.apache.openjpa.kernel.PCState
Persistent-New-Flushed-Deleted-Flushed
PNEWPROVISIONAL - Static variable in class org.apache.openjpa.kernel.PCState
Persistent-New-Provisional
PNONTRANS - Static variable in class org.apache.openjpa.kernel.PCState
Persistent-Nontransactinoal
PNONTRANSDELETED - Static variable in class org.apache.openjpa.kernel.PCState
Persistent-Deleted-Nontransactional
PNonTransDeletedState - Class in org.apache.openjpa.kernel
Lifecycle state.
PNonTransDeletedState() - Constructor for class org.apache.openjpa.kernel.PNonTransDeletedState
 
PNONTRANSDIRTY - Static variable in class org.apache.openjpa.kernel.PCState
Persistent-Dirty-Nontransactinoal
PNONTRANSNEW - Static variable in class org.apache.openjpa.kernel.PCState
Persistent-New-Nontransactional
PointbaseDictionary - Class in org.apache.openjpa.jdbc.sql
Dictionary for Pointbase Embedded.
PointbaseDictionary() - Constructor for class org.apache.openjpa.jdbc.sql.PointbaseDictionary
 
POLICY_EMPTY - Static variable in class org.apache.openjpa.enhance.DynamicStorageGenerator
Constant to not generate type set/get methods.
POLICY_EXCEPTION - Static variable in class org.apache.openjpa.enhance.DynamicStorageGenerator
Constant to throw an exception on invalid index passed to type set/get methods
POLICY_SILENT - Static variable in class org.apache.openjpa.enhance.DynamicStorageGenerator
Constant to be as silent as possible during invalid index passed to set/get type methods.
poll() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentLinkedQueue
 
poll() - Method in interface org.apache.openjpa.lib.util.concurrent.Queue
Retrieves and removes the head of this queue, or returns null if this queue is empty.
POLY_FALSE - Static variable in interface org.apache.openjpa.jdbc.meta.ValueMapping
A non-polymorphic relation.
POLY_JOINABLE - Static variable in interface org.apache.openjpa.jdbc.meta.ValueMapping
A relation that can hold any joinable subclass type.
POLY_TRUE - Static variable in interface org.apache.openjpa.jdbc.meta.ValueMapping
A fully polymorphic relation (the default).
pool() - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
Add the factory to the pool.
popElement() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Pop a parse element from the stack.
populate(Table, Table, Column, Object, boolean, int, int) - Method in interface org.apache.openjpa.jdbc.meta.MappingInfo.ForeignKeyDefaults
Populate the given foreign key column with defaults.
populate(Object, ExpressionStoreQuery) - Method in interface org.apache.openjpa.kernel.exps.ExpressionParser
Use the parsed query form to set information such as candidate type, result type, etc that was encoded in the query string.
populate(Object, ExpressionStoreQuery) - Method in class org.apache.openjpa.kernel.jpql.JPQLParser
 
populate(ClassMetaData, int) - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
 
populate(FieldMetaData) - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
Populate initial field data.
populate(ClassMetaData, int) - Method in interface org.apache.openjpa.meta.MetaDataDefaults
Populate the given metadata with default settings.
populate(ClassMetaData, int) - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
populate(ClassMetaData, int) - Method in class org.apache.openjpa.persistence.PersistenceMetaDataDefaults
 
populate(FieldMetaData) - Method in class org.apache.openjpa.persistence.PersistenceMetaDataDefaults
 
populateColumns(Version, Table, Column[]) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Fill in default information for the given version columns.
populateColumns(Discriminator, Table, Column[]) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Fill in default information for the given discriminator columns.
populateColumns(ValueMapping, String, Table, Column[]) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Fill in default information for the given value columns.
populateColumns(Version, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
populateColumns(Discriminator, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
populateColumns(ValueMapping, String, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
populateColumns(Version, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
populateColumns(Discriminator, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
populateColumns(ValueMapping, String, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
populateColumns(Version, Table, Column[]) - Method in class org.apache.openjpa.persistence.jdbc.PersistenceMappingDefaults
 
populateConfiguration(Configuration, Options) - Static method in class org.apache.openjpa.lib.conf.Configurations
Set the given Configuration instance from the command line options provided.
populateDataStoreIdColumns(ClassMapping, Table, Column[]) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Fill in default information for the given datastore identity columns.
populateDataStoreIdColumns(ClassMapping, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
populateDataStoreIdColumns(ClassMapping, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
populateForeignKeyColumn(ValueMapping, String, Table, Table, Column, Object, boolean, int, int) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Fill in default information for the given column used to join a value to its related type.
populateForeignKeyColumn(ValueMapping, String, Table, Table, Column, Object, boolean, int, int) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
populateForeignKeyColumn(ValueMapping, String, Table, Table, Column, Object, boolean, int, int) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
populateForeignKeyColumn(ValueMapping, String, Table, Table, Column, Object, boolean, int, int) - Method in class org.apache.openjpa.persistence.jdbc.PersistenceMappingDefaults
 
populateFromCompilation(Object) - Method in class org.apache.openjpa.datacache.QueryCacheStoreQuery
 
populateFromCompilation(Object) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery
 
populateFromCompilation(Object) - Method in class org.apache.openjpa.kernel.ExpressionStoreQuery
 
populateFromCompilation(Object) - Method in interface org.apache.openjpa.kernel.StoreQuery
Populate internal data from compilation.
populateJoinColumn(ClassMapping, Table, Table, Column, Object, int, int) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Fill in default information for the given column used to join a class to its superclass table.
populateJoinColumn(FieldMapping, Table, Table, Column, Object, int, int) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Fill in default information for the given column used to join a field to its defining class' table.
populateJoinColumn(ClassMapping, Table, Table, Column, Object, int, int) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
populateJoinColumn(FieldMapping, Table, Table, Column, Object, int, int) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
populateJoinColumn(ClassMapping, Table, Table, Column, Object, int, int) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
populateJoinColumn(FieldMapping, Table, Table, Column, Object, int, int) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
populateJoinColumn(FieldMapping, Table, Table, Column, Object, int, int) - Method in class org.apache.openjpa.persistence.jdbc.PersistenceMappingDefaults
 
populateNullIndicatorColumns(ValueMapping, String, Table, Column[]) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Fill in default information for the given null indicator columns.
populateNullIndicatorColumns(ValueMapping, String, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
populateNullIndicatorColumns(ValueMapping, String, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
populateOrderColumns(FieldMapping, Table, Column[]) - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
Fill in default information for the given order columns.
populateOrderColumns(FieldMapping, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
populateOrderColumns(FieldMapping, Table, Column[]) - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
pos - Variable in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
POSTFIX - Static variable in class org.apache.openjpa.datacache.DataCachePCDataGenerator
 
POSTFIX - Static variable in class org.apache.openjpa.enhance.PCDataGenerator
 
PostgresDictionary - Class in org.apache.openjpa.jdbc.sql
Dictionary for Postgres.
PostgresDictionary() - Constructor for class org.apache.openjpa.jdbc.sql.PostgresDictionary
 
preFlush() - Method in interface org.apache.openjpa.kernel.Broker
Run pre-flush actions on transactional objects, including persistence-by-reachability, inverse relationship management, deletion of dependent instances, and instance callbacks.
preFlush() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
preFlush() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
preFlush() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
preFlush() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Run pre-flush actions on transactional objects, including persistence-by-reachability, inverse relationship management, deletion of dependent instances, and instance callbacks.
premain(String, Instrumentation) - Static method in class org.apache.openjpa.enhance.PCEnhancerAgent
 
prepareCall(Connection) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Create and populate the parameters of a prepared statement using the SQL in this buffer.
prepareCall(Connection, int, int) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Create and populate the parameters of a prepared statement using the SQL in this buffer.
prepareCall(Connection, JDBCFetchConfiguration, int, int) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Create and populate the parameters of a prepred statement using the SQL in this buffer and the given fetch configuration.
prepareCall(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
prepareCall(String, boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
Prepare a call, with the option of not wrapping it in a DelegatingCallableStatement, which is the default.
prepareCall(String, int, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
prepareCall(String, int, int, boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
Prepare a call, with the option of not wrapping it in a DelegatingCallableStatement, which is the default.
prepareCall(String, int, int, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
prepareCall(String, int, int, int, boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
PreparedStatementManager - Interface in org.apache.openjpa.jdbc.kernel
Manages prepared statement execution.
prepareMapping(ClassMetaData) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
 
prepareMapping(ClassMetaData) - Method in class org.apache.openjpa.meta.MetaDataRepository
Prepare metadata for mapping resolution.
prepareStatement(String, boolean) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager.RefCountConnection
 
prepareStatement(String, int, int, boolean) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager.RefCountConnection
 
prepareStatement(Connection) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Create and populate the parameters of a prepared statement using the SQL in this buffer.
prepareStatement(Connection, int, int) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Create and populate the parameters of a prepared statement using the SQL in this buffer.
prepareStatement(Connection, JDBCFetchConfiguration, int, int) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Create and populate the parameters of a prepred statement using the SQL in this buffer and the given fetch configuration.
prepareStatement(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
prepareStatement(String, boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
Prepare a statement, with the option of not wrapping it in a DelegatingPreparedStatement, which is the default.
prepareStatement(String, int, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
prepareStatement(String, int, int, boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
Prepare a statement, with the option of not wrapping it in a DelegatingPreparedStatement, which is the default.
prepareStatement(String, int, int, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
prepareStatement(String, int, int, int, boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
prepareStatement(String, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
prepareStatement(String, int, boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
prepareStatement(String, int[]) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
prepareStatement(String, int[], boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
prepareStatement(String, String[]) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
prepareStatement(String, String[], boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
prepareWrite(File) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
Prepare to write to the given file.
PRETTY - Static variable in interface org.apache.openjpa.lib.meta.MetaDataSerializer
 
prettyPrint(Object) - Method in class org.apache.openjpa.lib.jdbc.SQLFormatter
 
previous() - Method in class org.apache.openjpa.kernel.DelegatingResultList.DelegatingListIterator
 
previous() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
previous() - Method in class org.apache.openjpa.lib.rop.ResultListIterator
 
previousIndex() - Method in class org.apache.openjpa.kernel.DelegatingResultList.DelegatingListIterator
 
previousIndex() - Method in class org.apache.openjpa.lib.rop.ResultListIterator
 
PrimaryKey - Class in org.apache.openjpa.jdbc.schema
Represents a table primary key.
PrimaryKey() - Constructor for class org.apache.openjpa.jdbc.schema.PrimaryKey
Default constructor.
PrimaryKey(String, Table) - Constructor for class org.apache.openjpa.jdbc.schema.PrimaryKey
Constructor.
primaryKeyOnJoin - Variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool.Flags
 
primaryKeys - Variable in class org.apache.openjpa.jdbc.meta.MappingTool.Flags
 
primaryKeys - Variable in class org.apache.openjpa.jdbc.schema.SchemaTool.Flags
 
PrimaryRow - Class in org.apache.openjpa.jdbc.sql
Primary table row that tracks foreign keys and auto-inc columns.
PrimaryRow(Table, int, OpenJPAStateManager) - Constructor for class org.apache.openjpa.jdbc.sql.PrimaryRow
Constructor; supply table and action.
PrimitiveFieldStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Direct mapping from a primitive value to a column.
PrimitiveFieldStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
printNestedThrowables(ExceptionInfo, PrintStream) - Static method in class org.apache.openjpa.util.Exceptions
Print the stack trace of the exception's nested throwables.
printNestedThrowables(ExceptionInfo, PrintWriter) - Static method in class org.apache.openjpa.util.Exceptions
Print the stack trace of the exception's nested throwables.
printStackTrace() - Method in exception org.apache.openjpa.persistence.ArgumentException
 
printStackTrace(PrintStream) - Method in exception org.apache.openjpa.persistence.ArgumentException
 
printStackTrace(PrintWriter) - Method in exception org.apache.openjpa.persistence.ArgumentException
 
printStackTrace() - Method in exception org.apache.openjpa.persistence.EntityExistsException
 
printStackTrace(PrintStream) - Method in exception org.apache.openjpa.persistence.EntityExistsException
 
printStackTrace(PrintWriter) - Method in exception org.apache.openjpa.persistence.EntityExistsException
 
printStackTrace() - Method in exception org.apache.openjpa.persistence.EntityNotFoundException
 
printStackTrace(PrintStream) - Method in exception org.apache.openjpa.persistence.EntityNotFoundException
 
printStackTrace(PrintWriter) - Method in exception org.apache.openjpa.persistence.EntityNotFoundException
 
printStackTrace() - Method in exception org.apache.openjpa.persistence.InvalidStateException
 
printStackTrace(PrintStream) - Method in exception org.apache.openjpa.persistence.InvalidStateException
 
printStackTrace(PrintWriter) - Method in exception org.apache.openjpa.persistence.InvalidStateException
 
printStackTrace() - Method in exception org.apache.openjpa.persistence.NonUniqueResultException
 
printStackTrace(PrintStream) - Method in exception org.apache.openjpa.persistence.NonUniqueResultException
 
printStackTrace(PrintWriter) - Method in exception org.apache.openjpa.persistence.NonUniqueResultException
 
printStackTrace() - Method in exception org.apache.openjpa.persistence.NoResultException
 
printStackTrace(PrintStream) - Method in exception org.apache.openjpa.persistence.NoResultException
 
printStackTrace(PrintWriter) - Method in exception org.apache.openjpa.persistence.NoResultException
 
printStackTrace() - Method in exception org.apache.openjpa.persistence.OptimisticLockException
 
printStackTrace(PrintStream) - Method in exception org.apache.openjpa.persistence.OptimisticLockException
 
printStackTrace(PrintWriter) - Method in exception org.apache.openjpa.persistence.OptimisticLockException
 
printStackTrace() - Method in exception org.apache.openjpa.persistence.PersistenceException
 
printStackTrace(PrintStream) - Method in exception org.apache.openjpa.persistence.PersistenceException
 
printStackTrace(PrintWriter) - Method in exception org.apache.openjpa.persistence.PersistenceException
 
printStackTrace() - Method in exception org.apache.openjpa.persistence.RollbackException
 
printStackTrace(PrintStream) - Method in exception org.apache.openjpa.persistence.RollbackException
 
printStackTrace(PrintWriter) - Method in exception org.apache.openjpa.persistence.RollbackException
 
printStackTrace() - Method in exception org.apache.openjpa.persistence.TransactionRequiredException
 
printStackTrace(PrintStream) - Method in exception org.apache.openjpa.persistence.TransactionRequiredException
 
printStackTrace(PrintWriter) - Method in exception org.apache.openjpa.persistence.TransactionRequiredException
 
printStackTrace() - Method in interface org.apache.openjpa.util.ExceptionInfo
Stack.
printStackTrace() - Method in exception org.apache.openjpa.util.OpenJPAException
 
printStackTrace(PrintStream) - Method in exception org.apache.openjpa.util.OpenJPAException
 
printStackTrace(PrintWriter) - Method in exception org.apache.openjpa.util.OpenJPAException
 
processArgument(Object) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
processArgument(Object) - Method in interface org.apache.openjpa.kernel.FindCallbacks
Process find argument.
processArgument(int, Object, OpenJPAStateManager) - Method in interface org.apache.openjpa.kernel.OpCallbacks
Process operation argument.
processArgument(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
processArgument(int, Object, OpenJPAStateManager) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
processReturn(Object, OpenJPAStateManager) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
processReturn(Object, OpenJPAStateManager) - Method in interface org.apache.openjpa.kernel.FindCallbacks
Process operation return value.
processReturn(Object, OpenJPAStateManager) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
ProductDerivation - Interface in org.apache.openjpa.lib.conf
Hooks for deriving products with additional functionality.
ProductDerivations - Class in org.apache.openjpa.lib.conf
Utilities for running product derivations.
ProductDerivations() - Constructor for class org.apache.openjpa.lib.conf.ProductDerivations
 
project(QueryExpressions, List, StoreContext, Object[]) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
Create the projections for the given results.
projectionAliases - Variable in class org.apache.openjpa.kernel.exps.QueryExpressions
 
projectionClauses - Variable in class org.apache.openjpa.kernel.exps.QueryExpressions
 
projections - Variable in class org.apache.openjpa.jdbc.kernel.exps.QueryExpressionsState
 
projections - Variable in class org.apache.openjpa.kernel.exps.QueryExpressions
 
promote(Class, Class) - Static method in class org.apache.openjpa.kernel.Filters
Given two types, return type they should both be converted to before performing any operations between them.
PROP_ABSTRACT_STORE - Static variable in class org.apache.openjpa.abstractstore.AbstractStoreBrokerFactory
The property name under which to name the concrete store manager class for this runtime.
PropertiesReverseCustomizer - Class in org.apache.openjpa.jdbc.meta
Simple ReverseCustomizer that uses a properties file to to allow customization of basic class and field properties.
PropertiesReverseCustomizer() - Constructor for class org.apache.openjpa.jdbc.meta.PropertiesReverseCustomizer
 
providedBooleanField(PersistenceCapable, int, boolean) - Method in interface org.apache.openjpa.enhance.StateManager
Provide state callback.
providedBooleanField(PersistenceCapable, int, boolean) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
providedBooleanField(PersistenceCapable, int, boolean) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
providedBooleanField(PersistenceCapable, int, boolean) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
providedBooleanField(PersistenceCapable, int, boolean) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
providedByteField(PersistenceCapable, int, byte) - Method in interface org.apache.openjpa.enhance.StateManager
Provide state callback.
providedByteField(PersistenceCapable, int, byte) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
providedByteField(PersistenceCapable, int, byte) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
providedByteField(PersistenceCapable, int, byte) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
providedByteField(PersistenceCapable, int, byte) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
providedCharField(PersistenceCapable, int, char) - Method in interface org.apache.openjpa.enhance.StateManager
Provide state callback.
providedCharField(PersistenceCapable, int, char) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
providedCharField(PersistenceCapable, int, char) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
providedCharField(PersistenceCapable, int, char) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
providedCharField(PersistenceCapable, int, char) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
providedDoubleField(PersistenceCapable, int, double) - Method in interface org.apache.openjpa.enhance.StateManager
Provide state callback.
providedDoubleField(PersistenceCapable, int, double) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
providedDoubleField(PersistenceCapable, int, double) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
providedDoubleField(PersistenceCapable, int, double) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
providedDoubleField(PersistenceCapable, int, double) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
providedFloatField(PersistenceCapable, int, float) - Method in interface org.apache.openjpa.enhance.StateManager
Provide state callback.
providedFloatField(PersistenceCapable, int, float) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
providedFloatField(PersistenceCapable, int, float) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
providedFloatField(PersistenceCapable, int, float) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
providedFloatField(PersistenceCapable, int, float) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
providedIntField(PersistenceCapable, int, int) - Method in interface org.apache.openjpa.enhance.StateManager
Provide state callback.
providedIntField(PersistenceCapable, int, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
providedIntField(PersistenceCapable, int, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
providedIntField(PersistenceCapable, int, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
providedIntField(PersistenceCapable, int, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
providedLongField(PersistenceCapable, int, long) - Method in interface org.apache.openjpa.enhance.StateManager
Provide state callback.
providedLongField(PersistenceCapable, int, long) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
providedLongField(PersistenceCapable, int, long) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
providedLongField(PersistenceCapable, int, long) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
providedLongField(PersistenceCapable, int, long) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
providedObjectField(PersistenceCapable, int, Object) - Method in interface org.apache.openjpa.enhance.StateManager
Provide state callback.
providedObjectField(PersistenceCapable, int, Object) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
providedObjectField(PersistenceCapable, int, Object) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
providedObjectField(PersistenceCapable, int, Object) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
providedObjectField(PersistenceCapable, int, Object) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
providedShortField(PersistenceCapable, int, short) - Method in interface org.apache.openjpa.enhance.StateManager
Provide state callback.
providedShortField(PersistenceCapable, int, short) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
providedShortField(PersistenceCapable, int, short) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
providedShortField(PersistenceCapable, int, short) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
providedShortField(PersistenceCapable, int, short) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
providedStringField(PersistenceCapable, int, String) - Method in interface org.apache.openjpa.enhance.StateManager
Provide state callback.
providedStringField(PersistenceCapable, int, String) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
providedStringField(PersistenceCapable, int, String) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
providedStringField(PersistenceCapable, int, String) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
providedStringField(PersistenceCapable, int, String) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
provideField(Object, StateManagerImpl, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
Proxies - Class in org.apache.openjpa.util
Utility methods for managing proxies.
Proxies() - Constructor for class org.apache.openjpa.util.Proxies
 
Proxy - Interface in org.apache.openjpa.util
Interface implemented by all proxy types to allow setting and nulling of their owning instance.
ProxyArrayList - Class in org.apache.openjpa.util
Extension of the ArrayList type that dirties the persistent/transactional field it is assigned to on modification.
ProxyArrayList() - Constructor for class org.apache.openjpa.util.ProxyArrayList
 
ProxyArrayList(Class, boolean, OpenJPAConfiguration) - Constructor for class org.apache.openjpa.util.ProxyArrayList
 
ProxyCalendar - Interface in org.apache.openjpa.util
Interface implemented by all built-in proxies on Calendar types.
ProxyCollection - Interface in org.apache.openjpa.util
Interface implemented by all built-in proxies on Collection types.
ProxyDate - Interface in org.apache.openjpa.util
Interface implemented by all built-in proxies on Date types.
proxyDetachedDeserialized(int) - Method in interface org.apache.openjpa.enhance.StateManager
Proxy the given detached field after deserialization.
proxyDetachedDeserialized(int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
proxyDetachedDeserialized(int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
proxyDetachedDeserialized(int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
proxyDetachedDeserialized(int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
ProxyGregorianCalendar - Class in org.apache.openjpa.util
Extension of the Calendar type that calls the dirty method on its owning persistence capable instance on modification.
ProxyGregorianCalendar() - Constructor for class org.apache.openjpa.util.ProxyGregorianCalendar
 
ProxyGregorianCalendar(int, int, int) - Constructor for class org.apache.openjpa.util.ProxyGregorianCalendar
 
ProxyGregorianCalendar(int, int, int, int, int) - Constructor for class org.apache.openjpa.util.ProxyGregorianCalendar
 
ProxyGregorianCalendar(int, int, int, int, int, int) - Constructor for class org.apache.openjpa.util.ProxyGregorianCalendar
 
ProxyGregorianCalendar(Locale) - Constructor for class org.apache.openjpa.util.ProxyGregorianCalendar
 
ProxyGregorianCalendar(TimeZone) - Constructor for class org.apache.openjpa.util.ProxyGregorianCalendar
 
ProxyGregorianCalendar(TimeZone, Locale) - Constructor for class org.apache.openjpa.util.ProxyGregorianCalendar
 
ProxyHashMap - Class in org.apache.openjpa.util
Extension of the HashMap type that dirties the persistent/transactional field it is assigned to on modification.
ProxyHashMap() - Constructor for class org.apache.openjpa.util.ProxyHashMap
 
ProxyHashMap(Class, Class, boolean, OpenJPAConfiguration) - Constructor for class org.apache.openjpa.util.ProxyHashMap
 
ProxyHashSet - Class in org.apache.openjpa.util
Extension of the HashSet type that dirties the persistent/transactional field it is assigned to on modification.
ProxyHashSet() - Constructor for class org.apache.openjpa.util.ProxyHashSet
 
ProxyHashSet(Class, boolean, OpenJPAConfiguration) - Constructor for class org.apache.openjpa.util.ProxyHashSet
 
ProxyHashtable - Class in org.apache.openjpa.util
Extension of the Hashtable type that dirties the persistent/transactional field it is assigned to on modification.
ProxyHashtable() - Constructor for class org.apache.openjpa.util.ProxyHashtable
 
ProxyHashtable(Class, Class, boolean, OpenJPAConfiguration) - Constructor for class org.apache.openjpa.util.ProxyHashtable
 
ProxyLinkedList - Class in org.apache.openjpa.util
Extension of the LinkedList type that dirties the persistent/transactional field it is assigned to on modification.
ProxyLinkedList() - Constructor for class org.apache.openjpa.util.ProxyLinkedList
 
ProxyLinkedList(Class, boolean, OpenJPAConfiguration) - Constructor for class org.apache.openjpa.util.ProxyLinkedList
 
ProxyManager - Interface in org.apache.openjpa.util
Manager for copying and proxying second class objects.
ProxyManagerImpl - Class in org.apache.openjpa.util
Default implementation of the ProxyManager interface.
ProxyManagerImpl() - Constructor for class org.apache.openjpa.util.ProxyManagerImpl
 
proxyManagerPlugin - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
ProxyMap - Interface in org.apache.openjpa.util
Interface implemented by all built-in proxies on Map types.
ProxyProperties - Class in org.apache.openjpa.util
Extension of the Properties type that dirties the persistent/transactional field it is assigned to on modification.
ProxyProperties() - Constructor for class org.apache.openjpa.util.ProxyProperties
 
ProxyProperties(boolean, OpenJPAConfiguration) - Constructor for class org.apache.openjpa.util.ProxyProperties
 
ProxySQLDate - Class in org.apache.openjpa.util
Extension of the Date type that calls the dirty method on its owning persistence capable instance on modification.
ProxySQLDate() - Constructor for class org.apache.openjpa.util.ProxySQLDate
 
ProxySQLDate(long) - Constructor for class org.apache.openjpa.util.ProxySQLDate
 
ProxyTime - Class in org.apache.openjpa.util
Extension of the Time type that calls the dirty method on its owning persistence capable instance on modification.
ProxyTime() - Constructor for class org.apache.openjpa.util.ProxyTime
 
ProxyTime(long) - Constructor for class org.apache.openjpa.util.ProxyTime
 
ProxyTimestamp - Class in org.apache.openjpa.util
Extension of the Timestamp type that calls the dirty method on its owning persistence capable instance on modification.
ProxyTimestamp() - Constructor for class org.apache.openjpa.util.ProxyTimestamp
 
ProxyTimestamp(long) - Constructor for class org.apache.openjpa.util.ProxyTimestamp
 
ProxyTreeMap - Class in org.apache.openjpa.util
Extension of the TreeMap type that dirties the persistent/transactional field it is assigned to on modification.
ProxyTreeMap() - Constructor for class org.apache.openjpa.util.ProxyTreeMap
 
ProxyTreeMap(Class, Class, boolean, OpenJPAConfiguration) - Constructor for class org.apache.openjpa.util.ProxyTreeMap
 
ProxyTreeMap(Class, Class, Comparator, boolean, OpenJPAConfiguration) - Constructor for class org.apache.openjpa.util.ProxyTreeMap
 
ProxyTreeSet - Class in org.apache.openjpa.util
Extension of the TreeSet type that dirties the persistent/transactional field it is assigned to on modification.
ProxyTreeSet() - Constructor for class org.apache.openjpa.util.ProxyTreeSet
 
ProxyTreeSet(Class, boolean, OpenJPAConfiguration) - Constructor for class org.apache.openjpa.util.ProxyTreeSet
 
ProxyTreeSet(Class, Comparator, boolean, OpenJPAConfiguration) - Constructor for class org.apache.openjpa.util.ProxyTreeSet
 
ProxyUtilDate - Class in org.apache.openjpa.util
Extension of the Date type that calls the dirty method on its owning persistence capable instance on modification.
ProxyUtilDate() - Constructor for class org.apache.openjpa.util.ProxyUtilDate
 
ProxyUtilDate(long) - Constructor for class org.apache.openjpa.util.ProxyUtilDate
 
ProxyVector - Class in org.apache.openjpa.util
Extension of the Vector type that dirties the persistent/transactional field it is assigned to on modification.
ProxyVector() - Constructor for class org.apache.openjpa.util.ProxyVector
 
ProxyVector(Class, boolean, OpenJPAConfiguration) - Constructor for class org.apache.openjpa.util.ProxyVector
 
purge(Reference) - Method in class org.apache.openjpa.lib.util.ReferenceHashMap
 
pushBack() - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
pushBack() - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
pushBack() - Method in interface org.apache.openjpa.jdbc.sql.Result
Push back the last result.
pushBack() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
pushElement(Object) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Push a parse element onto the stack.
put(DataCachePCData) - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
put(QueryKey, QueryResult) - Method in class org.apache.openjpa.datacache.AbstractQueryCache
 
put(DataCachePCData) - Method in interface org.apache.openjpa.datacache.DataCache
Set the cached value for the given instance.
put(DataCachePCData) - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
put(QueryKey, QueryResult) - Method in class org.apache.openjpa.datacache.DelegatingQueryCache
 
put(QueryKey, QueryResult) - Method in interface org.apache.openjpa.datacache.QueryCache
Set the list of OIDs for the given query key.
put(Object, Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
Associates the specified value with the specified key in this map.
put(Object, Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
Associates the specified value with the specified key in this HashMap.
put(Object, Object) - Method in class org.apache.openjpa.lib.util.FormatPreservingProperties
 
put(Object, Object) - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
put(Map, Object, Object) - Method in class org.apache.openjpa.util.CacheMap
Put the given entry into the given map.
put(Object, Object) - Method in class org.apache.openjpa.util.CacheMap
 
put(Object, Object) - Method in class org.apache.openjpa.util.ProxyHashMap
 
put(Object, Object) - Method in class org.apache.openjpa.util.ProxyHashtable
 
put(Object, Object) - Method in class org.apache.openjpa.util.ProxyProperties
 
put(Object, Object) - Method in class org.apache.openjpa.util.ProxyTreeMap
 
putAll(Map) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
Copies all of the mappings from the specified map to this map These mappings will replace any mappings that this map had for any of the keys currently in the specified map.
putAll(Map) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
Copies all of the mappings from the specified Map to this HashMap These mappings will replace any mappings that this HashMap had for any of the keys currently in the specified Map.
putAll(Map) - Method in class org.apache.openjpa.lib.util.FormatPreservingProperties
Circumvents the superclass FormatPreservingProperties.putAll(java.util.Map) implementation, putting all the key-value pairs via FormatPreservingProperties.put(java.lang.Object, java.lang.Object).
putAll(Map) - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
putAll(Map) - Method in class org.apache.openjpa.util.CacheMap
 
putAll(Map) - Method in class org.apache.openjpa.util.ProxyHashMap
 
putAll(Map) - Method in class org.apache.openjpa.util.ProxyHashtable
 
putAll(Map) - Method in class org.apache.openjpa.util.ProxyProperties
 
putAll(Map) - Method in class org.apache.openjpa.util.ProxyTreeMap
 
putAllInternal(Collection) - Method in class org.apache.openjpa.datacache.AbstractDataCache
All all of the given objects to the cache.
putBrokerFactoryAliases(Map) - Method in interface org.apache.openjpa.conf.OpenJPAProductDerivation
Load default alias options into the given map.
putBrokerFactoryAliases(Map) - Method in class org.apache.openjpa.jdbc.conf.JDBCProductDerivation
 
putBrokerFactoryAliases(Map) - Method in class org.apache.openjpa.persistence.jdbc.JDBCPersistenceProductDerivation
 
putBrokerFactoryAliases(Map) - Method in class org.apache.openjpa.persistence.PersistenceProductDerivation
 
putBytes(Object, byte[]) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Invoke the JDK 1.4 setBytes method on the given BLOB object.
putBytes(Object, byte[]) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
Invoke Oracle's putBytes method on the given BLOB object.
putChars(Object, char[]) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Invoke the JDK 1.4 setCharacterStream method on the given CLOB object.
putChars(Object, char[]) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
Invoke Oracle's putChars method on the given CLOB object.
putData(OpenJPAStateManager, ResultSet, DBDictionary) - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedBlobFieldStrategy
 
putData(OpenJPAStateManager, ResultSet, DBDictionary) - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedByteArrayFieldStrategy
 
putData(OpenJPAStateManager, ResultSet, DBDictionary) - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedCharArrayFieldStrategy
 
putData(OpenJPAStateManager, ResultSet, DBDictionary) - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedClobFieldStrategy
 
putEager(FieldMapping, Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
putEager(FieldMapping, Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
putEager(FieldMapping, Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
The eager result for the given key, or null if none.
putEager(FieldMapping, Object) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
putIfAbsent(Object, Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
 
putInternal(Object, DataCachePCData) - Method in class org.apache.openjpa.datacache.AbstractDataCache
Add the given object to the cache, returning the old object under the given oid.
putInternal(QueryKey, QueryResult) - Method in class org.apache.openjpa.datacache.AbstractQueryCache
Add the given result to the cache, returning the old result under the given key.
putInternal(Object, DataCachePCData) - Method in class org.apache.openjpa.datacache.ConcurrentDataCache
 
putInternal(QueryKey, QueryResult) - Method in class org.apache.openjpa.datacache.ConcurrentQueryCache
 
putString(Object, String) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Invoke the JDK 1.4 setString method on the given CLOB object.
putString(Object, String) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
Invoke Oracle's putString method on the given CLOB object.
putUpdate(FieldMetaData, Value) - Method in class org.apache.openjpa.kernel.exps.QueryExpressions
Add an update.
putUserObject(Object, Object) - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
 
putUserObject(Object, Object) - Method in interface org.apache.openjpa.kernel.Broker
Put the specified key-value pair into the map of user objects.
putUserObject(Object, Object) - Method in interface org.apache.openjpa.kernel.BrokerFactory
Put the specified key-value pair into the map of user objects.
putUserObject(Object, Object) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
putUserObject(Object, Object) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
putUserObject(Object, Object) - Method in class org.apache.openjpa.kernel.DelegatingBrokerFactory
 
putUserObject(Object, Object) - Method in class org.apache.openjpa.persistence.EntityManagerFactoryImpl
 
putUserObject(Object, Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
putUserObject(Object, Object) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Put the specified key-value pair into the map of user objects.
putUserObject(Object, Object) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManagerFactory
Put the specified key-value pair into the map of user objects.

Q

Query - Interface in org.apache.openjpa.kernel
OpenJPA query interface.
QueryCache - Interface in org.apache.openjpa.datacache
Interface that must be implemented by any level 2 query cache used by OpenJPA.
queryCache - Variable in class org.apache.openjpa.kernel.FetchConfigurationImpl.ConfigurationState
 
queryCachePlugin - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
QueryCacheStoreQuery - Class in org.apache.openjpa.datacache
A StoreQuery implementation that caches the OIDs involved in the query, and can determine whether or not the query has been dirtied.
QueryCacheStoreQuery(StoreQuery, QueryCache) - Constructor for class org.apache.openjpa.datacache.QueryCacheStoreQuery
Create a new instance that delegates to query if no cached results are available.
QueryCacheStoreQuery.CachedList - Class in org.apache.openjpa.datacache
Result list implementation for a cached query result.
QueryCacheStoreQuery.CachedList(QueryResult, boolean, StoreContext) - Constructor for class org.apache.openjpa.datacache.QueryCacheStoreQuery.CachedList
 
queryCompilationCachePlugin - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
QueryCompilationCacheValue - Class in org.apache.openjpa.conf
A cache of compiled queries.
QueryCompilationCacheValue(String) - Constructor for class org.apache.openjpa.conf.QueryCompilationCacheValue
 
QueryContext - Interface in org.apache.openjpa.kernel
A query execution context.
QueryExpressions - Class in org.apache.openjpa.kernel.exps
Struct to hold the state of a parsed expression query.
QueryExpressions() - Constructor for class org.apache.openjpa.kernel.exps.QueryExpressions
 
QueryExpressionsState - Class in org.apache.openjpa.jdbc.kernel.exps
Struct to hold the state of a query expressions instance.
QueryExpressionsState() - Constructor for class org.apache.openjpa.jdbc.kernel.exps.QueryExpressionsState
 
QueryFlushModes - Interface in org.apache.openjpa.kernel
Constants for determining when to flush before queries.
QueryImpl - Class in org.apache.openjpa.kernel
Implementation of the Query interface.
QueryImpl(Broker, String, StoreQuery) - Constructor for class org.apache.openjpa.kernel.QueryImpl
Construct a query managed by the given broker.
QueryImpl - Class in org.apache.openjpa.persistence
Implementation of Query interface.
QueryImpl(EntityManagerImpl, Query) - Constructor for class org.apache.openjpa.persistence.QueryImpl
Constructor; supply factory and delegate.
QueryImpl.Compilation - Class in org.apache.openjpa.kernel
Struct of compiled query properties.
QueryImpl.Compilation() - Constructor for class org.apache.openjpa.kernel.QueryImpl.Compilation
 
QueryImpl.RemoveOnCloseResultList - Class in org.apache.openjpa.kernel
Result list that removes itself from the query's open result list when it is closed.
QueryImpl.RemoveOnCloseResultList(ResultList) - Constructor for class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
QueryKey - Class in org.apache.openjpa.datacache
This class stores information about a particular invocation of a query.
QueryKey() - Constructor for class org.apache.openjpa.datacache.QueryKey
Public constructor for externalization only.
QueryLanguages - Class in org.apache.openjpa.kernel
Constants and utilities for query languages.
QueryLanguages() - Constructor for class org.apache.openjpa.kernel.QueryLanguages
 
QueryMetaData - Class in org.apache.openjpa.meta
Holds metadata about named queries.
QueryMetaData(String) - Constructor for class org.apache.openjpa.meta.QueryMetaData
Construct with the given name.
QueryOperations - Interface in org.apache.openjpa.kernel
Query operation constants.
QueryResult - Class in org.apache.openjpa.datacache
A query result.
QueryResult(QueryKey, Collection) - Constructor for class org.apache.openjpa.datacache.QueryResult
Constructor; supply corresponding query key and result data.
QueryResult(Collection, long) - Constructor for class org.apache.openjpa.datacache.QueryResult
Constructor to set internal data from a serializer.
QueryResultCache - Interface in org.apache.openjpa.persistence
Query result cache.
QueryResultCacheImpl - Class in org.apache.openjpa.persistence
Implements Query result cache via delegation to QueryCache.
QueryResultCacheImpl(QueryCache) - Constructor for class org.apache.openjpa.persistence.QueryResultCacheImpl
Constructor; supply delegate.
QueryResultMapping - Class in org.apache.openjpa.jdbc.meta
Mapping of a query result set to scalar and/or persistence-capable object-level values.
QueryResultMapping.PCResult - Class in org.apache.openjpa.jdbc.meta
A persistence-capable result.
Queue - Interface in org.apache.openjpa.lib.util.concurrent
A collection designed for holding elements prior to processing.

R

RandomAccessResultList - Class in org.apache.openjpa.lib.rop
Random-access result list implementation.
RandomAccessResultList(ResultObjectProvider) - Constructor for class org.apache.openjpa.lib.rop.RandomAccessResultList
 
randomEntryIterator() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
 
randomEntryIterator() - Method in interface org.apache.openjpa.lib.util.concurrent.ConcurrentMap
Iterate over map entries, beginning at an arbitrary (not strictly random) entry.
randomEntryIterator() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
 
range - Variable in class org.apache.openjpa.kernel.exps.QueryExpressions
 
RANGE_POST_DISTINCT - Static variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
RANGE_POST_LOCK - Static variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
RANGE_POST_SELECT - Static variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
RANGE_PRE_DISTINCT - Static variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
rangePosition - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
RangeResultObjectProvider - Class in org.apache.openjpa.lib.rop
Prevents a view of a given range of indices from the delegate result object provider.
RangeResultObjectProvider(ResultObjectProvider, long, long) - Constructor for class org.apache.openjpa.lib.rop.RangeResultObjectProvider
Constructor.
Raw - Class in org.apache.openjpa.jdbc.sql
Represents a raw SQL string for passing to Row.setObject.
Raw(String) - Constructor for class org.apache.openjpa.jdbc.sql.Raw
 
read() - Method in class org.apache.openjpa.lib.xml.DocTypeReader
 
read(char[]) - Method in class org.apache.openjpa.lib.xml.DocTypeReader
 
read(char[], int, int) - Method in class org.apache.openjpa.lib.xml.DocTypeReader
 
READ_OK - Static variable in interface org.apache.openjpa.enhance.PersistenceCapable
 
READ_WRITE_OK - Static variable in interface org.apache.openjpa.enhance.PersistenceCapable
 
readExternal(ObjectInput) - Method in class org.apache.openjpa.datacache.QueryKey
 
readExternal(ObjectInput) - Method in class org.apache.openjpa.event.RemoteCommitEvent
 
readExternal(ObjectInput) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
Implementation of the Externalizable interface to read from the properties written by ConfigurationImpl.writeExternal(java.io.ObjectOutput).
readLock() - Method in class org.apache.openjpa.util.CacheMap
Acquire read lock.
readLockLevel - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
readLockLevel - Variable in class org.apache.openjpa.kernel.FetchConfigurationImpl.ConfigurationState
 
ReadOnly - Annotation Type in org.apache.openjpa.persistence
Marks a field read-only.
readResolve() - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
Replaces the factory with this JVMs pooled version if it exists.
readResolve() - Method in class org.apache.openjpa.kernel.PCState
 
readSchema - Variable in class org.apache.openjpa.jdbc.meta.MappingTool.Flags
 
readSchema() - Method in class org.apache.openjpa.jdbc.schema.DynamicSchemaFactory
 
readSchema() - Method in class org.apache.openjpa.jdbc.schema.FileSchemaFactory
 
readSchema() - Method in class org.apache.openjpa.jdbc.schema.LazySchemaFactory
 
readSchema() - Method in interface org.apache.openjpa.jdbc.schema.SchemaFactory
Return the schema group for the current object model and database.
readSchema() - Method in class org.apache.openjpa.jdbc.schema.TableSchemaFactory
 
readSchemaColumn() - Method in class org.apache.openjpa.jdbc.schema.TableSchemaFactory
Returns the schema as an XML string.
readUnlock() - Method in class org.apache.openjpa.util.CacheMap
Release read lock.
ready() - Method in class org.apache.openjpa.lib.xml.DocTypeReader
 
realTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
recacheUpdates() - Method in class org.apache.openjpa.datacache.AbstractDataCache
Return true if updates to data already in the cache (either in AbstractDataCache.commit(java.util.Collection, java.util.Collection, java.util.Collection, java.util.Collection) or the AbstractDataCache.update(org.apache.openjpa.datacache.DataCachePCData)) should be put back into the cache.
recheck(WaitQueue.WaitNode) - Method in interface org.apache.openjpa.lib.util.concurrent.WaitQueue.QueuedSync
 
record() - Method in class org.apache.openjpa.enhance.ApplicationIdTool
Writes the generated code to the proper file.
record() - Method in class org.apache.openjpa.enhance.PCEnhancer
Write the generated bytecode.
record() - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Records the changes that have been made to both the mappings and the associated schema, and clears the tool for further use.
record - Variable in class org.apache.openjpa.jdbc.schema.SchemaTool.Flags
 
record() - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Record the changes made to the DB in the current SchemaFactory.
record() - Method in class org.apache.openjpa.meta.MetaDataTool
Record metadata changes.
recordCode() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Uses CodeGenerators to write the Java code for the generated mappings to the proper packages.
recordCode(Map) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Write the code for the tool.
recordMetaData(boolean) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Write the generated metadata to the proper packages.
recordMetaData(boolean, Map) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Write the code for the tool.
recordOrder(Object, boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
Record that we're ordering by a SQL expression.
recordOrderColumns(Column[], boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
Record that we're ordering by the given columns.
RECURSION_DEPTH_DEFAULT - Static variable in class org.apache.openjpa.meta.FetchGroup
Default field recursion depth.
ReentrantLock - Class in org.apache.openjpa.lib.util.concurrent
A reentrant mutual exclusion Lock with the same basic behavior and semantics as the implicit monitor lock accessed using synchronized methods and statements, but with extended capabilities.
ReentrantLock() - Constructor for class org.apache.openjpa.lib.util.concurrent.ReentrantLock
Creates an instance of ReentrantLock.
ReentrantLock(boolean) - Constructor for class org.apache.openjpa.lib.util.concurrent.ReentrantLock
Creates an instance of ReentrantLock with the given fairness policy.
ref() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager.RefCountConnection
 
REF - Static variable in class org.apache.openjpa.jdbc.meta.JavaSQLTypes
 
refColumns() - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Ref all columns in this key.
refColumns() - Method in class org.apache.openjpa.jdbc.schema.LocalConstraint
Ref all columns in this constraint.
ReferenceHashMap - Class in org.apache.openjpa.lib.util
Map in which the key, value, or both may be weak/soft references.
ReferenceHashMap(int, int) - Constructor for class org.apache.openjpa.lib.util.ReferenceHashMap
 
ReferenceHashMap(int, int, int, float) - Constructor for class org.apache.openjpa.lib.util.ReferenceHashMap
 
ReferenceHashSet - Class in org.apache.openjpa.lib.util
A set whose values may be stored as weak or soft references.
ReferenceHashSet(int) - Constructor for class org.apache.openjpa.lib.util.ReferenceHashSet
Construct a set with the given reference type.
ReferenceMap - Interface in org.apache.openjpa.lib.util
A Map type that can hold its keys, values, or both with weak or soft references.
REFERENTIAL_INTEGRITY - Static variable in exception org.apache.openjpa.util.StoreException
 
ReferentialIntegrityException - Exception in org.apache.openjpa.util
Exception type reserved for violations of integrity constraints.
ReferentialIntegrityException(String) - Constructor for exception org.apache.openjpa.util.ReferentialIntegrityException
 
ReferentialIntegrityException(int) - Constructor for exception org.apache.openjpa.util.ReferentialIntegrityException
 
refresh(Object, OpCallbacks) - Method in interface org.apache.openjpa.kernel.Broker
Refresh the state of the given object.
refresh(Object, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
refresh(Object, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
refresh(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
refreshAll(Collection, OpCallbacks) - Method in interface org.apache.openjpa.kernel.Broker
Refresh the state of the given objects.
refreshAll(Collection, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
refreshAll(Collection, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
refreshAll() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
refreshAll(Collection) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
refreshAll(Object...) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
refreshAll(Object...) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Refresh the state of the given objects.
refreshAll(Collection) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Refresh the state of the given objects.
refreshAll() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Refresh all transactional objects.
refreshInternal(Collection, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
This method is called with the full set of objects reachable via cascade-refresh relations from the user-given instances.
refreshInternal(Object, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
Optimization for single-object refresh.
refreshRow() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
refreshSequence() - Method in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
Creates the sequence in the DB.
RefreshStrategyInstaller - Class in org.apache.openjpa.jdbc.meta
Attempts to install using the given mapping information.
RefreshStrategyInstaller(MappingRepository) - Constructor for class org.apache.openjpa.jdbc.meta.RefreshStrategyInstaller
Constructor; supply configuration.
refreshTable() - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
Creates the sequence table in the DB.
refreshTable() - Method in class org.apache.openjpa.jdbc.schema.TableSchemaFactory
Creates the schema table in the DB.
refSchemaComponents() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
refSchemaComponents() - Method in class org.apache.openjpa.jdbc.meta.Discriminator
Increment the reference count of used schema components.
refSchemaComponents() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Increment the reference count of used schema components.
refSchemaComponents() - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
Increase the reference count on used schema components.
refSchemaComponents() - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
refSchemaComponents() - Method in class org.apache.openjpa.jdbc.meta.Version
Increment the reference count of used schema components.
refSchemaComponents(Table) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Increment the reference count of any table components that this dictionary adds that are not used by mappings.
refSchemaComponents(Table) - Method in class org.apache.openjpa.jdbc.sql.SybaseDictionary
 
refTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
register(Class, String[], Class[], byte[], Class, String, PersistenceCapable) - Static method in class org.apache.openjpa.enhance.PCRegistry
Register metadata by class.
register(Class) - Method in interface org.apache.openjpa.enhance.PCRegistry.RegisterClassListener
 
register(Class) - Method in class org.apache.openjpa.meta.MetaDataRepository
 
registerImplementation(Class, Class, Class) - Method in class org.apache.openjpa.util.StoreFacadeTypeRegistry
Register a facade implementation.
registerOutParameter(int, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
registerOutParameter(int, int, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
registerOutParameter(int, int, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
registerOutParameter(String, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
registerOutParameter(String, int, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
registerOutParameter(String, int, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
RelationCollectionInverseKeyFieldStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Maps a relation to a collection of other objects using an inverse foreign key in the related object table.
RelationCollectionInverseKeyFieldStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.RelationCollectionInverseKeyFieldStrategy
 
RelationCollectionTableFieldStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Maps a collection of related objects through an association table.
RelationCollectionTableFieldStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.RelationCollectionTableFieldStrategy
 
RelationFieldStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Mapping for a single-valued relation to another entity.
RelationFieldStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
RelationId - Interface in org.apache.openjpa.jdbc.meta
Callback to store a relation after the object id has been assigned.
RelationMapInverseKeyFieldStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Uses an inverse foreign key in the table of the map value to determine map values.
RelationMapInverseKeyFieldStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.RelationMapInverseKeyFieldStrategy
 
RelationMapTableFieldStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Uses an association table to hold map values.
RelationMapTableFieldStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.RelationMapTableFieldStrategy
 
RelationStrategies - Class in org.apache.openjpa.jdbc.meta.strats
Helper methods for relation mappings.
RelationStrategies() - Constructor for class org.apache.openjpa.jdbc.meta.strats.RelationStrategies
 
RelationToManyInverseKeyFieldStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Maps a relation to a set of other objects using an inverse foreign key in the related object table.
RelationToManyInverseKeyFieldStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.RelationToManyInverseKeyFieldStrategy
 
RelationToManyTableFieldStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Maps a set of related objects through an association table.
RelationToManyTableFieldStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.RelationToManyTableFieldStrategy
 
relative(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
release(Object, OpCallbacks) - Method in interface org.apache.openjpa.kernel.Broker
Release the given object from management.
release(Object, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
release(Object, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
release(OpenJPAStateManager) - Method in interface org.apache.openjpa.kernel.LockManager
Release the lock on the given object.
release(OpenJPAStateManager) - Method in class org.apache.openjpa.kernel.NoneLockManager
 
release(boolean) - Method in class org.apache.openjpa.kernel.OpenJPASavepoint
Release this savepoint and any associated resources.
release(OpenJPAStateManager) - Method in class org.apache.openjpa.kernel.VersionLockManager
Nulls given instance's lock object.
release(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
release(Object) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Release the given object from management.
RELEASE_STATUS - Static variable in class org.apache.openjpa.conf.OpenJPAVersion
 
releaseAll(Collection, OpCallbacks) - Method in interface org.apache.openjpa.kernel.Broker
Release the given objects from management.
releaseAll(Collection, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
releaseAll(Collection, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
releaseAll(Collection) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
releaseAll(Object...) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
releaseAll(Object...) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Release the given object from management.
releaseAll(Collection) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Release the given objects from management.
releaseConnection() - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
Override to release previously-retained connection.
releaseConnection() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
releaseConnection() - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
releaseConnection() - Method in interface org.apache.openjpa.kernel.StoreManager
Instruct the store to release a retained connection.
releaseSavepoint() - Method in interface org.apache.openjpa.kernel.Broker
Release the last set savepoint and any resources associated with it.
releaseSavepoint(String) - Method in interface org.apache.openjpa.kernel.Broker
Release the savepoint and any resources associated with it.
releaseSavepoint() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
releaseSavepoint(String) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
releaseSavepoint() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
releaseSavepoint(String) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
releaseSavepoint(Savepoint) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
releaseSavepoint() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
releaseSavepoint(String) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
releaseSavepoint() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Release the last set savepoint and any resources associated with it.
releaseSavepoint(String) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Release the savepoint and any resources associated with it.
rem - Variable in class org.apache.openjpa.util.AbstractChangeTracker
Collection of removed items.
RemoteCommitEvent - Class in org.apache.openjpa.event
Event type to hold the IDs of additions, updates, and deletes.
RemoteCommitEvent() - Constructor for class org.apache.openjpa.event.RemoteCommitEvent
Constructor used during externalization.
RemoteCommitEvent(int, Collection, Collection, Collection, Collection) - Constructor for class org.apache.openjpa.event.RemoteCommitEvent
Constructor.
RemoteCommitEventManager - Class in org.apache.openjpa.event
Manager that can be used to track and notify RemoteCommitListeners on remote commit events.
RemoteCommitEventManager(OpenJPAConfiguration) - Constructor for class org.apache.openjpa.event.RemoteCommitEventManager
Constructor.
RemoteCommitListener - Interface in org.apache.openjpa.event
An entity that wishes to be notified when Brokers associated with remote BrokerFactories commit.
RemoteCommitProvider - Interface in org.apache.openjpa.event
An entity that is responsible for communicating commit notification to other RemoteCommitEventManagers.
RemoteCommitProviderValue - Class in org.apache.openjpa.conf
Value type used to represent a RemoteCommitProvider.
RemoteCommitProviderValue() - Constructor for class org.apache.openjpa.conf.RemoteCommitProviderValue
 
remoteEventManager - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
remoteProviderPlugin - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
remove(Object) - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
remove(QueryKey) - Method in class org.apache.openjpa.datacache.AbstractQueryCache
 
remove(Object) - Method in interface org.apache.openjpa.datacache.DataCache
Remove the value stored under the given oid.
remove(Object) - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
remove(QueryKey) - Method in class org.apache.openjpa.datacache.DelegatingQueryCache
 
remove(QueryKey) - Method in interface org.apache.openjpa.datacache.QueryCache
Remove the value stored under the given query key.
remove(Object) - Method in class org.apache.openjpa.event.LifecycleEventManager.ListenerList
 
remove() - Method in class org.apache.openjpa.kernel.DelegatingResultList.DelegatingListIterator
 
remove(Object) - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
remove(int) - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
remove(Object) - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
remove(int) - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
remove(int) - Method in class org.apache.openjpa.lib.rop.AbstractResultList
 
remove(Object) - Method in class org.apache.openjpa.lib.rop.AbstractResultList
 
remove() - Method in class org.apache.openjpa.lib.rop.ResultObjectProviderIterator
 
remove(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
Removes the mapping for this key from this map if present.
remove(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashSet
 
remove(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentLinkedQueue
Removes a single instance of the specified element from this queue, if it is present.
remove(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
Removes the mapping for this key from this HashMap if present.
remove(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashSet
 
remove(Object) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
remove(int) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
remove(Object) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArraySet
Removes the specified element from this set if it is present.
remove() - Method in interface org.apache.openjpa.lib.util.concurrent.Queue
Retrieves and removes the head of this queue.
remove(Object) - Method in class org.apache.openjpa.lib.util.FormatPreservingProperties
Removes the key from the bookkeeping collectiotns as well.
remove(Object) - Method in class org.apache.openjpa.lib.util.ReferenceHashSet
 
remove(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
remove(Object) - Method in class org.apache.openjpa.util.AbstractChangeTracker
Mark the given value as removed.
remove(Object) - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
remove(Object) - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
remove(Map, Object) - Method in class org.apache.openjpa.util.CacheMap
Remove the given key from the given map.
remove(Object) - Method in class org.apache.openjpa.util.CacheMap
If key is pinned into the cache, the pin is cleared and the object is removed.
remove(Object) - Method in class org.apache.openjpa.util.CollectionChangeTrackerImpl
 
remove(Object) - Method in class org.apache.openjpa.util.MapChangeTrackerImpl
 
remove(int) - Method in class org.apache.openjpa.util.ProxyArrayList
 
remove(Object) - Method in class org.apache.openjpa.util.ProxyArrayList
 
remove(Object) - Method in class org.apache.openjpa.util.ProxyHashMap
 
remove(Object) - Method in class org.apache.openjpa.util.ProxyHashSet
 
remove(Object) - Method in class org.apache.openjpa.util.ProxyHashtable
 
remove(int) - Method in class org.apache.openjpa.util.ProxyLinkedList
 
remove(Object) - Method in class org.apache.openjpa.util.ProxyLinkedList
 
remove(Object) - Method in class org.apache.openjpa.util.ProxyProperties
 
remove(Object) - Method in class org.apache.openjpa.util.ProxyTreeMap
 
remove(Object) - Method in class org.apache.openjpa.util.ProxyTreeSet
 
remove(int) - Method in class org.apache.openjpa.util.ProxyVector
 
remove(Object) - Method in class org.apache.openjpa.util.ProxyVector
 
removeAggregateListener(AggregateListener) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
removeAggregateListener(AggregateListener) - Method in interface org.apache.openjpa.kernel.Query
Remove an aggregate listener from the query.
removeAggregateListener(AggregateListener) - Method in class org.apache.openjpa.kernel.QueryImpl
 
removeAggregateListener(AggregateListener) - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Remove an aggregate listener from the query.
removeAggregateListener(AggregateListener) - Method in class org.apache.openjpa.persistence.QueryImpl
 
removeAll(Collection) - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
removeAll(Class, boolean) - Method in class org.apache.openjpa.datacache.AbstractDataCache
Remove the objects of the given class from the cache.
removeAll(Collection) - Method in interface org.apache.openjpa.datacache.DataCache
Remove the values stored under the given oids.
removeAll(Class, boolean) - Method in interface org.apache.openjpa.datacache.DataCache
Evict all values of a specified type.
removeAll(Collection) - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
removeAll(Class, boolean) - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
removeAll(Schema) - Method in interface org.apache.openjpa.jdbc.schema.SchemaSerializer
Remove the given schema's objects from the set to be serialized.
removeAll(SchemaGroup) - Method in interface org.apache.openjpa.jdbc.schema.SchemaSerializer
Remove all schemas in the given group from the set to be serialized.
removeAll(Schema) - Method in class org.apache.openjpa.jdbc.schema.XMLSchemaSerializer
 
removeAll(SchemaGroup) - Method in class org.apache.openjpa.jdbc.schema.XMLSchemaSerializer
 
removeAll(Collection) - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
removeAll(Collection) - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
removeAll(Collection) - Method in class org.apache.openjpa.lib.rop.AbstractResultList
 
removeAll(Collection) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashSet
 
removeAll(Collection) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashSet
 
removeAll(Collection) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
removeAll(Collection) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArraySet
Removes from this set all of its elements that are contained in the specified collection.
removeAll(Collection) - Method in class org.apache.openjpa.lib.util.ReferenceHashSet
 
removeAll(Object...) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
removeAll(Collection) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
removeAll(MetaDataRepository) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer
 
removeAll(Object...) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Delete the given persistent objects.
removeAll(Collection) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Delete the given persistent objects.
removeAll(MetaDataRepository) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Remove all the components in the given repository from the set to be serialized.
removeAll(Collection) - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
removeAll(Collection) - Method in class org.apache.openjpa.util.ProxyArrayList
 
removeAll(Collection) - Method in class org.apache.openjpa.util.ProxyHashSet
 
removeAll(Collection) - Method in class org.apache.openjpa.util.ProxyLinkedList
 
removeAll(Collection) - Method in class org.apache.openjpa.util.ProxyTreeSet
 
removeAll(Collection) - Method in class org.apache.openjpa.util.ProxyVector
 
removeAllElements() - Method in class org.apache.openjpa.util.ProxyVector
 
removeAllInternal(Class, boolean) - Method in class org.apache.openjpa.datacache.AbstractDataCache
Evict objects in cache by class.
removeAllInternal(Collection) - Method in class org.apache.openjpa.datacache.AbstractDataCache
Remove all objects under the given oids from the cache.
removeAllInternal(Collection) - Method in class org.apache.openjpa.datacache.AbstractQueryCache
Remove all results under the given keys from the cache.
removeAllInternal(Class, boolean) - Method in class org.apache.openjpa.datacache.ConcurrentDataCache
 
removeAllTypeNamesInternal(Collection) - Method in class org.apache.openjpa.datacache.AbstractDataCache
Remove all objects of the given class names from the cache.
removeBooleanProperty(String, String, boolean) - Method in class org.apache.openjpa.lib.util.Options
Specialization of TypedProperties.removeBooleanProperty(java.lang.String) to allow a value to appear under either of two keys; useful for short and long versions of command-line flags.
removeBooleanProperty(String) - Method in class org.apache.openjpa.lib.util.TypedProperties
Remove the property under the given key as a boolean.
removeBooleanProperty(String, boolean) - Method in class org.apache.openjpa.lib.util.TypedProperties
Remove the property under the given key as a boolean, or return the given default if it does not exist.
removeClassLoader(ClassLoader) - Method in class org.apache.openjpa.lib.util.MultiClassLoader
Remove the given loader from the list.
removeColumn(Column) - Method in class org.apache.openjpa.jdbc.schema.LocalConstraint
Remove a column from the constraint.
removeColumn(Column) - Method in class org.apache.openjpa.jdbc.schema.Table
Remove the given column from the table.
removed(int, Object, boolean) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
removed(int, Object, boolean) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
removed(int, Object, boolean) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
removed(int, Object, boolean) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Notification that an element has been removed from the given field.
removed(int, Object, boolean) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
removed(Object) - Method in class org.apache.openjpa.util.AbstractChangeTracker
Notify the tracker that the given object was removed.
removed(Object) - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
removed(Object, Object) - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
removed(Object) - Method in interface org.apache.openjpa.util.CollectionChangeTracker
Record that the given element was removed.
removed(Object) - Method in class org.apache.openjpa.util.CollectionChangeTrackerImpl
 
removed(Object, Object) - Method in interface org.apache.openjpa.util.MapChangeTracker
Record that the given entry was removed from the map.
removed(Object, Object) - Method in class org.apache.openjpa.util.MapChangeTrackerImpl
 
removed(Proxy, Object, boolean) - Static method in class org.apache.openjpa.util.Proxies
Used by proxy types to notify their owner that an element has been removed.
removeDeclaredFetchGroup(FetchGroup) - Method in class org.apache.openjpa.meta.ClassMetaData
Remove a declared fetch group.
removeDeclaredField(FieldMetaData) - Method in class org.apache.openjpa.meta.ClassMetaData
Remove the given field from management.
removeDeclaredInterface(Class) - Method in class org.apache.openjpa.meta.ClassMetaData
Remove the given interface from the declared list.
removeDecorator(ConnectionDecorator) - Method in class org.apache.openjpa.lib.jdbc.DecoratingDataSource
Remove a connection decorator.
removeDefinedSuperclassField(FieldMetaData) - Method in class org.apache.openjpa.meta.ClassMetaData
Remove the given field from management.
removeDoubleProperty(String, String, double) - Method in class org.apache.openjpa.lib.util.Options
Specialization of TypedProperties.removeDoubleProperty(java.lang.String) to allow a value to appear under either of two keys; useful for short and long versions of command-line flags.
removeDoubleProperty(String) - Method in class org.apache.openjpa.lib.util.TypedProperties
Remove the property under the given key as a double.
removeDoubleProperty(String, double) - Method in class org.apache.openjpa.lib.util.TypedProperties
Remove the property under the given key as a double, or return the given default if it does not exist.
removeElement(Object) - Method in class org.apache.openjpa.util.ProxyVector
 
removeElementAt(int) - Method in class org.apache.openjpa.util.ProxyVector
 
removeEmbeddedExtensions(String) - Method in class org.apache.openjpa.meta.Extensions
 
removeEmbeddedExtensions(String, String) - Method in class org.apache.openjpa.meta.Extensions
 
removeExpirationListener(ExpirationListener) - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
removeExpirationListener(ExpirationListener) - Method in interface org.apache.openjpa.datacache.DataCache
Remove an expiration event listener from this cache.
removeExpirationListener(ExpirationListener) - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
removeExpired() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
 
removeExpired() - Method in class org.apache.openjpa.lib.util.ReferenceHashMap
 
removeExpired() - Method in interface org.apache.openjpa.lib.util.ReferenceMap
Purge stale entries.
removeExtension(String) - Method in class org.apache.openjpa.meta.Extensions
Remove a vendor extension.
removeExtension(String, String) - Method in class org.apache.openjpa.meta.Extensions
Remove a vendor extension.
removeFetchGroup(String) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
removeFetchGroup(String) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Remove the given fetch group.
removeFetchGroup(String) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
removeFetchGroup(String) - Method in interface org.apache.openjpa.persistence.FetchPlan
Remove the given fetch group.
removeFetchGroup(String) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
removeFetchGroups(Collection) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
removeFetchGroups(Collection) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Removes groups from the set of fetch group names to use when loading objects.
removeFetchGroups(Collection) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
removeFetchGroups(String...) - Method in interface org.apache.openjpa.persistence.FetchPlan
Removes groups from the set of fetch group names to use when loading objects.
removeFetchGroups(Collection) - Method in interface org.apache.openjpa.persistence.FetchPlan
Removes groups from the set of fetch group names to use when loading objects.
removeFetchGroups(String...) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
removeFetchGroups(Collection) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
removeField(String) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
removeField(String) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Remove the given fully-qualified field.
removeField(String) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
removeField(String) - Method in interface org.apache.openjpa.persistence.FetchPlan
Remove the given fully-qualified field.
removeField(Class, String) - Method in interface org.apache.openjpa.persistence.FetchPlan
Remove the given field.
removeField(String) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
removeField(Class, String) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
removeFields(Collection) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
removeFields(Collection) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Removes fields from the set of fully-qualified field names to use when loading objects.
removeFields(Collection) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
removeFields(String...) - Method in interface org.apache.openjpa.persistence.FetchPlan
Removes fields from the set of fully-qualified field names to use when loading objects.
removeFields(Class, String...) - Method in interface org.apache.openjpa.persistence.FetchPlan
Removes fields from the set of field names to use when loading objects.
removeFields(Collection) - Method in interface org.apache.openjpa.persistence.FetchPlan
Removes fields from the set of fully-qualified field names to use when loading objects.
removeFields(Class, Collection) - Method in interface org.apache.openjpa.persistence.FetchPlan
Removes fields from the set of field names to use when loading objects.
removeFields(String...) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
removeFields(Class, String...) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
removeFields(Collection) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
removeFields(Class, Collection) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
removeFilterListener(FilterListener) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
removeFilterListener(FilterListener) - Method in interface org.apache.openjpa.kernel.Query
Remove a filter listener from the query.
removeFilterListener(FilterListener) - Method in class org.apache.openjpa.kernel.QueryImpl
 
removeFilterListener(FilterListener) - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Remove a filter listener from the query.
removeFilterListener(FilterListener) - Method in class org.apache.openjpa.persistence.QueryImpl
 
removeFirst() - Method in class org.apache.openjpa.util.ProxyLinkedList
 
removeFloatProperty(String, String, float) - Method in class org.apache.openjpa.lib.util.Options
Specialization of TypedProperties.removeFloatProperty(java.lang.String) to allow a value to appear under either of two keys; useful for short and long versions of command-line flags.
removeFloatProperty(String) - Method in class org.apache.openjpa.lib.util.TypedProperties
Remove the property under the given key as a float.
removeFloatProperty(String, float) - Method in class org.apache.openjpa.lib.util.TypedProperties
Remove the property under the given key as a float, or return the given default if it does not exist.
removeForeignKey(ForeignKey) - Method in class org.apache.openjpa.jdbc.schema.Table
Remove the given foreign key from the table.
removeFromCollection(OpenJPAStateManager, FieldMetaData, Object) - Method in class org.apache.openjpa.kernel.InverseManager
Remove the given instance from the collection.
removeFromSchedule(DataCache) - Method in class org.apache.openjpa.datacache.DataCacheScheduler
Remove the given cache from scheduling.
removeIndex(Index) - Method in class org.apache.openjpa.jdbc.schema.Table
Remove the given index from the table.
removeInternal(Object) - Method in class org.apache.openjpa.datacache.AbstractDataCache
Remove the object under the given oid from the cache.
removeInternal(QueryKey) - Method in class org.apache.openjpa.datacache.AbstractQueryCache
Remove the result under the given key from the cache.
removeInternal(Object) - Method in class org.apache.openjpa.datacache.ConcurrentDataCache
 
removeInternal(QueryKey) - Method in class org.apache.openjpa.datacache.ConcurrentQueryCache
 
removeIntProperty(String, String, int) - Method in class org.apache.openjpa.lib.util.Options
Specialization of TypedProperties.removeIntProperty(java.lang.String) to allow a value to appear under either of two keys; useful for short and long versions of command-line flags.
removeIntProperty(String) - Method in class org.apache.openjpa.lib.util.TypedProperties
Remove the property under the given key as a int.
removeIntProperty(String, int) - Method in class org.apache.openjpa.lib.util.TypedProperties
Remove the property under the given key as a int, or return the given default if it does not exist.
removeJoin(String) - Method in class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
 
removeJoin(String) - Method in interface org.apache.openjpa.jdbc.kernel.JDBCFetchConfiguration
Removes field to the set of fully-qualified field names to eagerly join when loading objects.
removeJoin(String) - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
removeJoin(Column) - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Remove any joins inolving the given column.
removeJoins(Collection) - Method in class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
 
removeJoins(Collection) - Method in interface org.apache.openjpa.jdbc.kernel.JDBCFetchConfiguration
Removes fields from the set of fully-qualified field names to eagerly join when loading objects.
removeJoins(Collection) - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
removeLast() - Method in class org.apache.openjpa.util.ProxyLinkedList
 
removeLifecycleListener(Object) - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
 
removeLifecycleListener(Object) - Method in interface org.apache.openjpa.kernel.Broker
Remove a listener for lifecycle-related events.
removeLifecycleListener(Object) - Method in interface org.apache.openjpa.kernel.BrokerFactory
Remove a listener for lifecycle-related events.
removeLifecycleListener(Object) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
removeLifecycleListener(Object) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
removeLifecycleListener(Object) - Method in class org.apache.openjpa.kernel.DelegatingBrokerFactory
 
removeLifecycleListener(Object) - Method in class org.apache.openjpa.persistence.EntityManagerFactoryImpl
 
removeLifecycleListener(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
removeLifecycleListener(Object) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Remove a listener for lifecycle-related events.
removeLifecycleListener(Object) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManagerFactory
Remove a listener for lifecycle-related events.
removeListener(Object) - Method in class org.apache.openjpa.event.LifecycleEventManager
Remove the given listener.
removeListener(Object) - Method in class org.apache.openjpa.event.TransactionEventManager
 
removeListener(SchemaGenerator.Listener) - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Removes a schema generation listener for schema events.
removeListener(Object) - Method in class org.apache.openjpa.lib.util.AbstractEventManager
Remove an event listener.
removeListener(Object) - Method in class org.apache.openjpa.lib.util.concurrent.AbstractConcurrentEventManager
Remove an event listener.
removeListener(Object) - Method in interface org.apache.openjpa.lib.util.EventManager
Remove an event listener.
removeLogFactory(LogFactory) - Method in class org.apache.openjpa.lib.log.MultiLogFactory
 
removeLongProperty(String, String, long) - Method in class org.apache.openjpa.lib.util.Options
Specialization of TypedProperties.removeLongProperty(java.lang.String) to allow a value to appear under either of two keys; useful for short and long versions of command-line flags.
removeLongProperty(String) - Method in class org.apache.openjpa.lib.util.TypedProperties
Remove the property under the given key as a long.
removeLongProperty(String, long) - Method in class org.apache.openjpa.lib.util.TypedProperties
Remove the property under the given key as a long, or return the given default if it does not exist.
removeLRU(AbstractLinkedMap.LinkEntry) - Method in class org.apache.openjpa.lib.util.LRUMap
 
removeMetaData(ClassMetaData) - Method in interface org.apache.openjpa.meta.AbstractCFMetaDataFactory.Serializer
Remove a class meta data from the set to be serialized.
removeMetaData(ClassMetaData) - Method in class org.apache.openjpa.meta.MetaDataRepository
Remove a metadata instance from the repository.
removeMetaData(Class) - Method in class org.apache.openjpa.meta.MetaDataRepository
Remove a metadata instance from the repository.
removeMetaData(ClassMetaData) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Remove a metadata from the set to be serialized.
removeName(String) - Method in class org.apache.openjpa.jdbc.schema.NameSet
Remove the given name from the table.
removeNonMappedInterface(Class) - Method in class org.apache.openjpa.meta.MetaDataRepository
Remove a non-mapped interface from the repository
removePersistenceAware(Class) - Method in class org.apache.openjpa.meta.MetaDataRepository
Remove a persitence-aware class from the repository
removePrimaryKey() - Method in class org.apache.openjpa.jdbc.schema.Table
Remove the primary key from this table.
removeProperty(String, Map) - Static method in class org.apache.openjpa.lib.conf.Configurations
Remove the property under the given key, prefixed with any possible configuration prefix.
removeProperty(String, String, String) - Method in class org.apache.openjpa.lib.util.Options
Specialization of Properties#removeProperty to allow a value to appear under either of two keys; useful for short and long versions of command-line flags.
removeProperty(String) - Method in class org.apache.openjpa.lib.util.TypedProperties
Remove the given property.
removeProperty(String, String) - Method in class org.apache.openjpa.lib.util.TypedProperties
Remove the given property, or return the given default if it does not exist.
removePropertyChangeListener(PropertyChangeListener) - Method in interface org.apache.openjpa.lib.conf.Configuration
Removes a listener for any property changes.
removePropertyChangeListener(PropertyChangeListener) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
removeProvider(ResourceBundleProvider) - Static method in class org.apache.openjpa.lib.util.Localizer
Remove a resource provider.
removeQueryMetaData(QueryMetaData) - Method in class org.apache.openjpa.meta.MetaDataRepository
Remove the given query metadata from the repository.
removeQueryMetaData(Class, String) - Method in class org.apache.openjpa.meta.MetaDataRepository
Remove query metadata for the given class name if in the repository.
removeQueryMetaData(QueryMetaData) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Remove a query metadata from the set to be serialized.
removeQueryResultMapping(QueryResultMapping) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Remove a query result mapping.
removeQueryResultMapping(Class, String) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Remove a query result mapping.
removeQueryResultMapping(QueryResultMapping) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer
Removes given result set mapping from the local cache.
removeRandom() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
 
removeRandom() - Method in interface org.apache.openjpa.lib.util.concurrent.ConcurrentMap
Remove an arbitrary(not strictly random) entry from the map.
removeRandom() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
 
removeRegisterClassListener(PCRegistry.RegisterClassListener) - Static method in class org.apache.openjpa.enhance.PCRegistry
Removes a PCRegistry.RegisterClassListener.
removeSchema(Schema) - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Remove the given schema from the group.
removeSequence(Sequence) - Method in class org.apache.openjpa.jdbc.schema.Schema
Remove the given sequence from the schema.
removeSequence(Sequence) - Method in class org.apache.openjpa.jdbc.schema.XMLSchemaSerializer
 
removeSequenceMetaData(SequenceMetaData) - Method in class org.apache.openjpa.meta.MetaDataRepository
Remove the given sequence metadata from the repository.
removeSequenceMetaData(String) - Method in class org.apache.openjpa.meta.MetaDataRepository
Remove sequence metadata for the name if in the repository.
removeSequenceMetaData(SequenceMetaData) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Remove a sequence metadata from the set to be serialized.
removeSystemListener(Object) - Method in class org.apache.openjpa.meta.MetaDataRepository
Remove the given system lifecycle listener.
removeTable(Table) - Method in class org.apache.openjpa.jdbc.schema.Schema
Remove the given table from the schema.
removeTable(Table) - Method in interface org.apache.openjpa.jdbc.schema.SchemaSerializer
Remove the given table from the set to be serialized.
removeTable(Table) - Method in class org.apache.openjpa.jdbc.schema.XMLSchemaSerializer
 
removeTransactionListener(Object) - Method in interface org.apache.openjpa.kernel.Broker
Remove a listener for transaction-related events.
removeTransactionListener(Object) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
removeTransactionListener(Object) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
removeTransactionListener(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
removeTransactionListener(Object) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Remove a listener for transaction-related events.
removeTypesChangedListener(TypesChangedListener) - Method in class org.apache.openjpa.datacache.AbstractQueryCache
 
removeTypesChangedListener(TypesChangedListener) - Method in class org.apache.openjpa.datacache.DelegatingQueryCache
 
removeTypesChangedListener(TypesChangedListener) - Method in interface org.apache.openjpa.datacache.QueryCache
Remove an types event listener from this cache.
removeUnique(Unique) - Method in class org.apache.openjpa.jdbc.schema.Table
Remove the given unique constraint from the table.
removeUnusedComponents() - Method in class org.apache.openjpa.jdbc.schema.SchemaGroup
Remove unreferenced or emtpy components from the schema.
removeValue(Value) - Method in interface org.apache.openjpa.lib.conf.Configuration
Remove the given value from the set of configuration properties.
removeValue(Value) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
replace(Select, Select) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Replace a subselect.
replaceBooleanField(PersistenceCapable, int) - Method in interface org.apache.openjpa.enhance.StateManager
Replace state callback.
replaceBooleanField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
replaceBooleanField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
replaceBooleanField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
replaceBooleanField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
replaceByteField(PersistenceCapable, int) - Method in interface org.apache.openjpa.enhance.StateManager
Replace state callback.
replaceByteField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
replaceByteField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
replaceByteField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
replaceByteField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
replaceCharField(PersistenceCapable, int) - Method in interface org.apache.openjpa.enhance.StateManager
Replace state callback.
replaceCharField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
replaceCharField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
replaceCharField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
replaceCharField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
replaceDoubleField(PersistenceCapable, int) - Method in interface org.apache.openjpa.enhance.StateManager
Replace state callback.
replaceDoubleField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
replaceDoubleField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
replaceDoubleField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
replaceDoubleField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
replaceFailedObject(Object) - Static method in class org.apache.openjpa.util.Exceptions
Convert the specified failed object into a serializable object for when we are serializing an Exception.
replaceFlags() - Method in interface org.apache.openjpa.enhance.StateManager
Change internal flags.
replaceFlags() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
replaceFlags() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
replaceFlags() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
replaceFlags() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
replaceFloatField(PersistenceCapable, int) - Method in interface org.apache.openjpa.enhance.StateManager
Replace state callback.
replaceFloatField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
replaceFloatField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
replaceFloatField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
replaceFloatField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
replaceIntField(PersistenceCapable, int) - Method in interface org.apache.openjpa.enhance.StateManager
Replace state callback.
replaceIntField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
replaceIntField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
replaceIntField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
replaceIntField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
replaceLongField(PersistenceCapable, int) - Method in interface org.apache.openjpa.enhance.StateManager
Replace state callback.
replaceLongField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
replaceLongField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
replaceLongField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
replaceLongField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
replaceMethod(BCClass, String, Class, Class[], boolean) - Method in class org.apache.openjpa.enhance.DynamicStorageGenerator
Clear code associated with the given method signature, and return the empty code.
replaceNestedThrowables(Throwable[]) - Static method in class org.apache.openjpa.util.Exceptions
Convert the specified throwables into a serialzable array.
replaceObjectField(PersistenceCapable, int) - Method in interface org.apache.openjpa.enhance.StateManager
Replace state callback.
replaceObjectField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
replaceObjectField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
replaceObjectField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
replaceObjectField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
replaceShortField(PersistenceCapable, int) - Method in interface org.apache.openjpa.enhance.StateManager
Replace state callback.
replaceShortField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
replaceShortField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
replaceShortField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
replaceShortField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
replaceStateManager(StateManager) - Method in interface org.apache.openjpa.enhance.StateManager
Change state manager.
replaceStateManager(StateManager) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
replaceStateManager(StateManager) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
replaceStateManager(StateManager) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
replaceStateManager(StateManager) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
replaceStringField(PersistenceCapable, int) - Method in interface org.apache.openjpa.enhance.StateManager
Replace state callback.
replaceStringField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
replaceStringField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
replaceStringField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
replaceStringField(PersistenceCapable, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
replaceType(FieldMetaData) - Method in class org.apache.openjpa.enhance.PCDataGenerator
Return a valid JavaTypes constant for the given field
ReportingSQLException - Exception in org.apache.openjpa.lib.jdbc
A SQLException that contains information about the Statement SQL that caused the exception.
ReportingSQLException(SQLException, Statement, String) - Constructor for exception org.apache.openjpa.lib.jdbc.ReportingSQLException
 
ReportingSQLException(SQLException, String) - Constructor for exception org.apache.openjpa.lib.jdbc.ReportingSQLException
 
ReportingSQLException(SQLException, Statement) - Constructor for exception org.apache.openjpa.lib.jdbc.ReportingSQLException
 
repos - Variable in class org.apache.openjpa.jdbc.meta.StrategyInstaller
 
repos - Variable in class org.apache.openjpa.meta.AbstractMetaDataFactory
 
requiresAliasForSubselect - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
requiresArgument() - Method in class org.apache.openjpa.event.MethodLifecycleCallbacks
Returns if this callback expects another argument
requiresAutoCommitForMetaData - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
requiresCandidateType() - Method in class org.apache.openjpa.datacache.QueryCacheStoreQuery
 
requiresCandidateType() - Method in class org.apache.openjpa.jdbc.kernel.SQLStoreQuery
 
requiresCandidateType() - Method in class org.apache.openjpa.kernel.AbstractStoreQuery
 
requiresCandidateType() - Method in interface org.apache.openjpa.kernel.StoreQuery
Whether this query requires a candidate class.
requiresCastForComparisons - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
requiresCastForMathFunctions - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
requiresConditionForCrossJoin - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
requiresFetch(FieldMetaData) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
requiresFetch(FieldMetaData) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Affirms if the given field requires to be fetched in the context of current fetch operation.
requiresFetch(FieldMetaData) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
requiresParameterDeclarations() - Method in class org.apache.openjpa.datacache.QueryCacheStoreQuery
 
requiresParameterDeclarations() - Method in class org.apache.openjpa.jdbc.kernel.SQLStoreQuery
 
requiresParameterDeclarations() - Method in class org.apache.openjpa.kernel.AbstractStoreQuery
 
requiresParameterDeclarations() - Method in interface org.apache.openjpa.kernel.StoreQuery
Whether this query requires parameters to be declared.
reservedWords - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
reservedWordSet - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
reset() - Method in class org.apache.openjpa.jdbc.kernel.GenericResultObjectProvider
 
reset() - Method in class org.apache.openjpa.jdbc.kernel.SelectResultObjectProvider
 
reset() - Method in class org.apache.openjpa.jdbc.schema.XMLSchemaParser
 
reset() - Method in class org.apache.openjpa.kernel.AbstractPCResultObjectProvider
Override if desired.
reset() - Method in class org.apache.openjpa.lib.meta.CFMetaDataParser
Override this method to clear any state and ready the parser for a new document.
reset() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Override this method to clear any state and ready the parser for a new document.
reset() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
Reset serialization state for the next document.
reset() - Method in class org.apache.openjpa.lib.rop.ListResultObjectProvider
 
reset() - Method in class org.apache.openjpa.lib.rop.MergedResultObjectProvider
 
reset() - Method in class org.apache.openjpa.lib.rop.RangeResultObjectProvider
 
reset() - Method in interface org.apache.openjpa.lib.rop.ResultObjectProvider
Reset this provider.
reset() - Method in class org.apache.openjpa.lib.xml.DocTypeReader
 
reset() - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingParser
 
reset() - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
reset() - Method in class org.apache.openjpa.util.AbstractChangeTracker
Reset the state of the tracker.
resetFetchGroups() - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
resetFetchGroups() - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Resets the set of fetch groups to the list in the global configuration.
resetFetchGroups() - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
resetFetchGroups() - Method in interface org.apache.openjpa.persistence.FetchPlan
Resets the set of fetch groups to the list in the global configuration.
resetFetchGroups() - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
resolve(int) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
Resolve mapping information.
resolve(int) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
resolve(int) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
resolve(int) - Method in class org.apache.openjpa.jdbc.meta.Version
Resolve mapping information.
resolve(int) - Method in class org.apache.openjpa.meta.ClassMetaData
Resolve and validate metadata.
resolve() - Method in class org.apache.openjpa.meta.FetchGroup
Resolve and validate fetch group metadata.
resolve(int) - Method in class org.apache.openjpa.meta.FieldMetaData
Resolve and validate metadata.
resolve(int) - Method in interface org.apache.openjpa.meta.ValueMetaData
Resolve and validate metadata.
resolve(int) - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
resolveConstraints() - Method in interface org.apache.openjpa.jdbc.schema.SchemaParser
If this parser is in delayed resolve mode, resolve all constraints.
resolveConstraints() - Method in class org.apache.openjpa.jdbc.schema.XMLSchemaParser
 
resolveMapping(boolean) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
resolveMapping(boolean) - Method in class org.apache.openjpa.meta.ClassMetaData
Resolve mapping data.
resolveMeta(boolean) - Method in class org.apache.openjpa.meta.ClassMetaData
Resolve metadata.
resolver - Variable in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
 
Resolver - Interface in org.apache.openjpa.kernel.exps
A Resolver is used to resolve listeners and class or entity names that appear in a query.
ResourceMetaDataIterator - Class in org.apache.openjpa.lib.meta
Iterator over a given metadata resource.
ResourceMetaDataIterator(String) - Constructor for class org.apache.openjpa.lib.meta.ResourceMetaDataIterator
Constructor; supply the resource to parse.
ResourceMetaDataIterator(String, ClassLoader) - Constructor for class org.apache.openjpa.lib.meta.ResourceMetaDataIterator
Constructor; supply the resource to parse.
respondsTo(int) - Method in interface org.apache.openjpa.event.LifecycleEventManager.ListenerAdapter
Return whether this instance responds to the given event type from LifecycleEvent.
RESTORE_ALL - Static variable in interface org.apache.openjpa.kernel.RestoreState
Restore all state on rollback.
RESTORE_IMMUTABLE - Static variable in interface org.apache.openjpa.kernel.RestoreState
Restore immutable state on rollback; clear mutable state.
RESTORE_NONE - Static variable in interface org.apache.openjpa.kernel.RestoreState
Do not restore any state on rollback.
restoreState - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
RestoreState - Interface in org.apache.openjpa.kernel
State restore constants.
RESTRICT - Static variable in class org.apache.openjpa.meta.UpdateStrategies
Throw an exception on attempt to update.
result - Variable in class org.apache.openjpa.jdbc.kernel.ConnectionInfo
 
Result - Interface in org.apache.openjpa.jdbc.sql
A result from the execution of a query or stored procedure.
resultClass - Variable in class org.apache.openjpa.kernel.exps.QueryExpressions
 
ResultList - Interface in org.apache.openjpa.lib.rop
List interface that represents a potentially lazy ResultList instantiation.
ResultListIterator - Class in org.apache.openjpa.lib.rop
Wrapper iterator that will return false for hasNext() if the owning ResultList has been closed.
ResultListIterator(ListIterator, ResultList) - Constructor for class org.apache.openjpa.lib.rop.ResultListIterator
 
ResultObjectProvider - Interface in org.apache.openjpa.lib.rop
Interface that allows lazy/custom instantiation of input objects.
ResultObjectProviderIterator - Class in org.apache.openjpa.lib.rop
Iterator wrapped around a ResultObjectProvider.
ResultObjectProviderIterator(ResultObjectProvider) - Constructor for class org.apache.openjpa.lib.rop.ResultObjectProviderIterator
Constructor.
ResultPacker - Class in org.apache.openjpa.kernel
Helper class to pack results into the result class set on the query.
ResultPacker(Class, String, Class) - Constructor for class org.apache.openjpa.kernel.ResultPacker
Constructor for result class without a projection.
ResultPacker(Class[], String[], Class) - Constructor for class org.apache.openjpa.kernel.ResultPacker
Constructor for standard projection.
ResultSetResult - Class in org.apache.openjpa.jdbc.sql
Base Result implementation wrapped around a result set.
ResultSetResult(Connection, Statement, ResultSet, DBDictionary) - Constructor for class org.apache.openjpa.jdbc.sql.ResultSetResult
Constructor.
ResultSetResult(Connection, Statement, ResultSet, JDBCStore) - Constructor for class org.apache.openjpa.jdbc.sql.ResultSetResult
Constructor.
ResultSetResult(ResultSet, DBDictionary) - Constructor for class org.apache.openjpa.jdbc.sql.ResultSetResult
JDBC 2 constructor.
ResultSetResult(ResultSet, JDBCStore) - Constructor for class org.apache.openjpa.jdbc.sql.ResultSetResult
JDBC 2 constructor.
resultSetType - Variable in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
retainAll(Collection) - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
retainAll(Collection) - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
retainAll(Collection) - Method in class org.apache.openjpa.lib.rop.AbstractResultList
 
retainAll(Collection) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashSet
 
retainAll(Collection) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashSet
 
retainAll(Collection) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
retainAll(Collection) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArraySet
Retains only the elements in this set that are contained in the specified collection.
retainAll(Collection) - Method in class org.apache.openjpa.lib.util.ReferenceHashSet
 
retainAll(Collection) - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
retainAll(Collection) - Method in class org.apache.openjpa.util.ProxyArrayList
 
retainAll(Collection) - Method in class org.apache.openjpa.util.ProxyHashSet
 
retainAll(Collection) - Method in class org.apache.openjpa.util.ProxyLinkedList
 
retainAll(Collection) - Method in class org.apache.openjpa.util.ProxyTreeSet
 
retainAll(Collection) - Method in class org.apache.openjpa.util.ProxyVector
 
retainConnection() - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
Override to retain a dedicated connection.
retainConnection() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
retainConnection() - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
retainConnection() - Method in interface org.apache.openjpa.kernel.StoreManager
Instruct the store to retain a connection for continued use.
retainState - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
retrieve(Object, boolean, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
retrieve(Object, boolean, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
retrieve(Object, boolean, OpCallbacks) - Method in interface org.apache.openjpa.kernel.StoreContext
Immediately load the given object's persistent fields.
retrieve(Object) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
retrieve(Object) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Immediately load the given object's persistent fields.
retrieveAll(Collection, boolean, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
retrieveAll(Collection, boolean, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
retrieveAll(Collection, boolean, OpCallbacks) - Method in interface org.apache.openjpa.kernel.StoreContext
Retrieve the given objects' persistent state.
retrieveAll(Collection) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
retrieveAll(Object...) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
retrieveAll(Object...) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Retrieve the persistent state of the given objects.
retrieveAll(Collection) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Retrieve the persistent state of the given objects.
retryClassRegistration - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
reverse() - Method in class org.apache.openjpa.jdbc.sql.Join
Return a join that is this join in reverse.
ReverseCustomizer - Interface in org.apache.openjpa.jdbc.meta
Plugin in interface to customize the output of the ReverseMappingTool.
ReverseMappingTool - Class in org.apache.openjpa.jdbc.meta
Reverse-maps a schema into class mappings and the assiciated java code.
ReverseMappingTool(JDBCConfiguration) - Constructor for class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Constructor.
ReverseMappingTool.Flags - Class in org.apache.openjpa.jdbc.meta
Holder for run flags.
ReverseMappingTool.Flags() - Constructor for class org.apache.openjpa.jdbc.meta.ReverseMappingTool.Flags
 
ReverseMappingToolTask - Class in org.apache.openjpa.jdbc.ant
Executes the ReverseMappingTool on the specified XML files.
ReverseMappingToolTask() - Constructor for class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
Default constructor.
ReverseMappingToolTask.Level - Class in org.apache.openjpa.jdbc.ant
 
ReverseMappingToolTask.Level() - Constructor for class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask.Level
 
revert(File, boolean) - Static method in class org.apache.openjpa.lib.util.Files
Revert the given backup file to the original location.
REVISION_NUMBER - Static variable in class org.apache.openjpa.conf.OpenJPAVersion
 
roll(int, boolean) - Method in class org.apache.openjpa.util.ProxyGregorianCalendar
 
roll(int, int) - Method in class org.apache.openjpa.util.ProxyGregorianCalendar
 
rollback() - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
This is a no-op implementation.
rollback() - Method in class org.apache.openjpa.datacache.DataCacheStoreManager
 
rollback(Collection) - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSavepointManager.ConnectionSavepoint
 
rollback() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
rollback() - Method in interface org.apache.openjpa.kernel.Broker
Rollback the current transaction.
rollback() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
rollback() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
rollback() - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
rollback(Collection) - Method in class org.apache.openjpa.kernel.OpenJPASavepoint
Handle the rolled back state, returning saved data.
rollback() - Method in interface org.apache.openjpa.kernel.StoreManager
Rollback the current data store transaction.
rollback() - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
rollback(Savepoint) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
rollback() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
rollback() - Method in class org.apache.openjpa.xmlstore.XMLStoreManager
 
rollbackAndResume() - Method in interface org.apache.openjpa.kernel.Broker
Issue a rollback and then start a new transaction.
rollbackAndResume() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
rollbackAndResume() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
rollbackAndResume() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
rollbackAndResume() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Issue a rollback and then start a new transaction.
rollbackDataStore(AbstractJDBCSavepointManager.ConnectionSavepoint) - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSavepointManager
Rollback the datastore savepoint.
rollbackDataStore(AbstractJDBCSavepointManager.ConnectionSavepoint) - Method in class org.apache.openjpa.jdbc.kernel.JDBC3SavepointManager
 
RollbackException - Exception in org.apache.openjpa.persistence
Rollback occurred on attempt to commit.
RollbackException(Exception) - Constructor for exception org.apache.openjpa.persistence.RollbackException
 
rollbackOptimistic() - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
No-op implementation.
rollbackOptimistic() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
rollbackOptimistic() - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
rollbackOptimistic() - Method in interface org.apache.openjpa.kernel.StoreManager
Notification that an optimistic transaction was rolled back before a data store transaction ever began.
rollbackToSavepoint() - Method in interface org.apache.openjpa.kernel.Broker
Rollback the current transaction to the last savepoint.
rollbackToSavepoint(String) - Method in interface org.apache.openjpa.kernel.Broker
Rollback the current transaction to the given savepoint name.
rollbackToSavepoint() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
rollbackToSavepoint(String) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
rollbackToSavepoint() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
rollbackToSavepoint(String) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
rollbackToSavepoint() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
rollbackToSavepoint(String) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
rollbackToSavepoint() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Rollback the current transaction to the last savepoint.
rollbackToSavepoint(String) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Rollback the current transaction to the given savepoint name.
rootClasses - Variable in class org.apache.openjpa.kernel.FetchConfigurationImpl.ConfigurationState
 
rootInstances - Variable in class org.apache.openjpa.kernel.FetchConfigurationImpl.ConfigurationState
 
Row - Interface in org.apache.openjpa.jdbc.sql
Logical representation of a table row for insert/update/delete.
rowDeleted() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
RowImpl - Class in org.apache.openjpa.jdbc.sql
Basic Row implementation.
RowImpl(Table, int) - Constructor for class org.apache.openjpa.jdbc.sql.RowImpl
Constructor.
rowInserted() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
RowManager - Interface in org.apache.openjpa.jdbc.sql
Manages rows during an insert/update/delete process.
RowManagerImpl - Class in org.apache.openjpa.jdbc.sql
Manages SQL rows during an insert/update/delete process.
RowManagerImpl(boolean) - Constructor for class org.apache.openjpa.jdbc.sql.RowManagerImpl
Constructor.
rowUpdated() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
RSRC_DEFAULT - Static variable in class org.apache.openjpa.persistence.PersistenceProductDerivation
 
RSRC_GLOBAL - Static variable in class org.apache.openjpa.persistence.PersistenceProductDerivation
 
rsrcs - Variable in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
 
run() - Method in class org.apache.openjpa.datacache.DataCacheScheduler
 
run() - Method in class org.apache.openjpa.enhance.ApplicationIdTool
Generates the sourcecode for the application id class; returns false if the class is invalid.
run(OpenJPAConfiguration, String[], Options) - Static method in class org.apache.openjpa.enhance.ApplicationIdTool
Run the application id tool with the given command-line and given configuration.
run(OpenJPAConfiguration, String[], ApplicationIdTool.Flags, ClassLoader) - Static method in class org.apache.openjpa.enhance.ApplicationIdTool
Run the tool.
run(BCClass, ClassMetaData) - Method in interface org.apache.openjpa.enhance.PCEnhancer.AuxiliaryEnhancer
 
run() - Method in class org.apache.openjpa.enhance.PCEnhancer
Perform bytecode enhancements.
run(OpenJPAConfiguration, String[], Options) - Static method in class org.apache.openjpa.enhance.PCEnhancer
Run the tool.
run(OpenJPAConfiguration, String[], PCEnhancer.Flags, MetaDataRepository, BytecodeWriter, ClassLoader) - Static method in class org.apache.openjpa.enhance.PCEnhancer
Enhance the given classes.
run(JDBCConfiguration, String[], Options) - Static method in class org.apache.openjpa.jdbc.kernel.ClassTableJDBCSeq
Run the tool.
run(JDBCConfiguration, String[], String, MappingRepository, ClassLoader) - Static method in class org.apache.openjpa.jdbc.kernel.ClassTableJDBCSeq
Run the tool.
run(JDBCConfiguration, String[], Options) - Static method in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
Run the tool.
run(JDBCConfiguration, String[], String) - Static method in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
Run the tool.
run(JDBCConfiguration, String[], Options) - Static method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
Run the tool.
run(JDBCConfiguration, String[], String) - Static method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
Run the tool.
run(JDBCConfiguration, String[], Options) - Static method in class org.apache.openjpa.jdbc.kernel.ValueTableJDBCSeq
Run the tool.
run(JDBCConfiguration, String[], String, MappingRepository, ClassLoader) - Static method in class org.apache.openjpa.jdbc.kernel.ValueTableJDBCSeq
Run the tool.
run(Class) - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Run the configured action on the given instance.
run(JDBCConfiguration, String[], Options) - Static method in class org.apache.openjpa.jdbc.meta.MappingTool
Run the tool.
run(JDBCConfiguration, String[], MappingTool.Flags, ClassLoader) - Static method in class org.apache.openjpa.jdbc.meta.MappingTool
Run the tool.
run() - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Generate mappings and class code for the current schema group.
run(JDBCConfiguration, String[], Options) - Static method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Run the tool.
run(JDBCConfiguration, String[], ReverseMappingTool.Flags, ClassLoader) - Static method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Run the tool.
run() - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Run the tool action.
run(JDBCConfiguration, String[], Options) - Static method in class org.apache.openjpa.jdbc.schema.SchemaTool
Run the tool.
run(JDBCConfiguration, String[], SchemaTool.Flags, ClassLoader) - Static method in class org.apache.openjpa.jdbc.schema.SchemaTool
Run the tool.
run(JDBCConfiguration, String[], Options) - Static method in class org.apache.openjpa.jdbc.schema.TableSchemaFactory
Run the tool.
run(JDBCConfiguration, String) - Static method in class org.apache.openjpa.jdbc.schema.TableSchemaFactory
Run the tool.
run(Class) - Method in class org.apache.openjpa.meta.MetaDataTool
Generate new metadata for the given class.
run(OpenJPAConfiguration, String[], Options) - Static method in class org.apache.openjpa.meta.MetaDataTool
Run the tool.
run(OpenJPAConfiguration, String[], MetaDataTool.Flags, MetaDataRepository, ClassLoader) - Static method in class org.apache.openjpa.meta.MetaDataTool
Run the tool.
RuntimeExceptionTranslator - Interface in org.apache.openjpa.util
Interface used by many facade helpers to translate exceptions.
RuntimeStrategyInstaller - Class in org.apache.openjpa.jdbc.meta
Installer that attempts to use the given mapping information, and fails if it does not work.
RuntimeStrategyInstaller(MappingRepository) - Constructor for class org.apache.openjpa.jdbc.meta.RuntimeStrategyInstaller
Constructor; supply configuration.

S

sameVersion(Object[], Object[]) - Static method in class org.apache.openjpa.util.ArrayStateImage
Return whether the given images are equivalent from an optimistic locking perspective.
save(Collection) - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSavepointManager.ConnectionSavepoint
 
save(Collection) - Method in class org.apache.openjpa.kernel.OpenJPASavepoint
Set this savepoint, saving any state for the passed-in OpenJPAStateManagers as necessary.
save(OutputStream, String) - Method in class org.apache.openjpa.lib.util.FormatPreservingProperties
 
SavepointManager - Interface in org.apache.openjpa.kernel
A manager for handling savepoints.
savepointManagerPlugin - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
scheduleEviction(DataCache, String) - Method in class org.apache.openjpa.datacache.DataCacheScheduler
Schedule the given cache for eviction.
schema - Variable in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
Schema - Class in org.apache.openjpa.jdbc.schema
Represents a database schema.
Schema() - Constructor for class org.apache.openjpa.jdbc.schema.Schema
Default constructor.
Schema(String, SchemaGroup) - Constructor for class org.apache.openjpa.jdbc.schema.Schema
Constructor.
SCHEMA_ACTION_NONE - Static variable in class org.apache.openjpa.jdbc.meta.MappingTool
 
SCHEMA_CASE_LOWER - Static variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
SCHEMA_CASE_PRESERVE - Static variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
SCHEMA_CASE_UPPER - Static variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
schemaAction - Variable in class org.apache.openjpa.jdbc.meta.MappingTool.Flags
 
schemaCase - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
SchemaFactory - Interface in org.apache.openjpa.jdbc.schema
Factory for SchemaGroups.
schemaFactoryPlugin - Variable in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
schemaFile - Variable in class org.apache.openjpa.jdbc.ant.MappingToolTask
 
SchemaGenerator - Class in org.apache.openjpa.jdbc.schema
The SchemaGenerator creates Schemas matching the current database.
SchemaGenerator(JDBCConfiguration) - Constructor for class org.apache.openjpa.jdbc.schema.SchemaGenerator
Constructor.
SchemaGenerator.Event - Class in org.apache.openjpa.jdbc.schema
An event corresponding to the generation of a schema object.
SchemaGenerator.Event(Object, int) - Constructor for class org.apache.openjpa.jdbc.schema.SchemaGenerator.Event
 
SchemaGenerator.Listener - Interface in org.apache.openjpa.jdbc.schema
A listener for a potentially lengthy schema generation process.
SchemaGroup - Class in org.apache.openjpa.jdbc.schema
Represents a grouping of schemas used in a database.
SchemaGroup() - Constructor for class org.apache.openjpa.jdbc.schema.SchemaGroup
 
schemaObjectGenerated(SchemaGenerator.Event) - Method in interface org.apache.openjpa.jdbc.schema.SchemaGenerator.Listener
 
SchemaParser - Interface in org.apache.openjpa.jdbc.schema
Interface class for parers that read schema information.
schemas - Variable in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
Schemas - Class in org.apache.openjpa.jdbc.schema
Helper class to deal with schemas.
Schemas() - Constructor for class org.apache.openjpa.jdbc.schema.Schemas
 
SchemaSerializer - Interface in org.apache.openjpa.jdbc.schema
Interface for schema serializers.
SchemaTool - Class in org.apache.openjpa.jdbc.schema
The SchemaTool is used to manage the database schema.
SchemaTool(JDBCConfiguration) - Constructor for class org.apache.openjpa.jdbc.schema.SchemaTool
Default constructor.
SchemaTool(JDBCConfiguration, String) - Constructor for class org.apache.openjpa.jdbc.schema.SchemaTool
Construct a tool to perform the given action.
SchemaTool.Flags - Class in org.apache.openjpa.jdbc.schema
Run flags.
SchemaTool.Flags() - Constructor for class org.apache.openjpa.jdbc.schema.SchemaTool.Flags
 
SchemaToolTask - Class in org.apache.openjpa.jdbc.ant
Executes the SchemaTool on the specified XML schema definition files.
SchemaToolTask() - Constructor for class org.apache.openjpa.jdbc.ant.SchemaToolTask
 
SchemaToolTask.Action - Class in org.apache.openjpa.jdbc.ant
 
SchemaToolTask.Action() - Constructor for class org.apache.openjpa.jdbc.ant.SchemaToolTask.Action
 
schemaWriter - Variable in class org.apache.openjpa.jdbc.meta.MappingTool.Flags
 
searchStringEscape - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
SEC - Static variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
SecondaryRow - Class in org.apache.openjpa.jdbc.sql
Secondary table row that tracks foreign keys to auto-inc columns.
SecondaryRow(Table, int) - Constructor for class org.apache.openjpa.jdbc.sql.SecondaryRow
Constructor; supply table and action.
SECONDS - Static variable in class org.apache.openjpa.lib.util.concurrent.TimeUnit
 
sel - Variable in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
select(Select, ExpContext, ExpState, boolean) - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
 
select(Select, ExpContext, ClassMapping, boolean, QueryExpressions, QueryExpressionsState, int) - Method in class org.apache.openjpa.jdbc.kernel.exps.SelectConstructor
Select the data for this query.
select(Select, ExpContext, ExpState, boolean) - Method in interface org.apache.openjpa.jdbc.kernel.exps.Val
Select the data for this value.
select(Select, ClassMapping, int, OpenJPAStateManager, BitSet, JDBCFetchConfiguration, int, boolean, boolean) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
For implementation use only.
select(Select, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
 
select(Select, ClassMapping) - Method in interface org.apache.openjpa.jdbc.meta.DiscriminatorStrategy
Select the data for this Discriminator.
select(Select, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
select(Select, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, int) - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Select the virtual row columns of this mapping.
select(Select, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractDiscriminatorStrategy
 
select(Select, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
select(Select, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractVersionStrategy
 
select(Select, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.ColumnVersionStrategy
 
select(Select, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedFieldStrategy
 
select(Select, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
select(Select, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.InValueDiscriminatorStrategy
 
select(Select, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
select(Select, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
select(Select, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
select(Select, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.SubclassJoinDiscriminatorStrategy
 
select(Select, ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.Version
 
select(Select, ClassMapping) - Method in interface org.apache.openjpa.jdbc.meta.VersionStrategy
Select the data for this indicator.
select(Union.Selector) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
select(Select, int) - Method in interface org.apache.openjpa.jdbc.sql.LogicalUnion.Selector
Populate the ith select in the union.
select(SQLBuffer, Object) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
select(SQLBuffer, Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
select(String, Object) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
select(String, Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
select(Column) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
select(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
select(Column[]) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
select(Column[], Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
select(ClassMapping, int, JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
select(ClassMapping, int, JDBCStore, JDBCFetchConfiguration, int, Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
Select - Interface in org.apache.openjpa.jdbc.sql
Abstraction of a SQL SELECT statement.
select(SQLBuffer, Object) - Method in interface org.apache.openjpa.jdbc.sql.Select
Select the given SQL; the given id object is an identifier to use when retrieving the corresponding value from a Result.
select(SQLBuffer, Object, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
Select the given SQL; the given id object is an identifier to use when retrieving the corresponding value from a Result.
select(String, Object) - Method in interface org.apache.openjpa.jdbc.sql.Select
Select the given SQL; the given id object is an identifier to use when retrieving the corresponding value from a Result.
select(String, Object, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
Select the given SQL; the given id object is an identifier to use when retrieving the corresponding value from a Result.
select(Column) - Method in interface org.apache.openjpa.jdbc.sql.Select
Select the given column.
select(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
Select the given column.
select(Column[]) - Method in interface org.apache.openjpa.jdbc.sql.Select
Select the given columns.
select(Column[], Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
Select the given columns.
select(ClassMapping, int, JDBCStore, JDBCFetchConfiguration, int) - Method in interface org.apache.openjpa.jdbc.sql.Select
Select the columns of the given mapping, possibly including subclasses.
select(ClassMapping, int, JDBCStore, JDBCFetchConfiguration, int, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
Select the columns of the given mapping, possibly including subclasses.
select(SQLBuffer, Object) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
select(SQLBuffer, Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
select(String, Object) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
select(String, Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
select(Column) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
select(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
select(Column[]) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
select(Column[], Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
select(ClassMapping, int, JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
select(ClassMapping, int, JDBCStore, JDBCFetchConfiguration, int, Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
select(Union.Selector) - Method in interface org.apache.openjpa.jdbc.sql.Union
Select data using the given selector.
select(Select, int) - Method in interface org.apache.openjpa.jdbc.sql.Union.Selector
Populate the ith select in the union.
SELECT_HINT - Static variable in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
selectAll(Select, ClassMapping, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.meta.strats.StoreCollectionFieldStrategy
Select data for loading, starting in field table.
selectColumns(Select, ExpContext, ExpState, boolean) - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
 
selectColumns(Select, ExpContext, ExpState, boolean) - Method in interface org.apache.openjpa.jdbc.kernel.exps.Val
Select just the columns for this value.
SelectConstructor - Class in org.apache.openjpa.jdbc.kernel.exps
Turns parsed queries into selects.
SelectConstructor() - Constructor for class org.apache.openjpa.jdbc.kernel.exps.SelectConstructor
 
selectEagerJoin(Select, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
selectEagerJoin(Select, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, int) - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Fill in joined select to related objects.
selectEagerJoin(Select, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
selectEagerJoin(Select, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
selectEagerJoin(Select, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.meta.strats.StoreCollectionFieldStrategy
 
selectEagerParallel(SelectExecutor, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
selectEagerParallel(SelectExecutor, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, int) - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Fill in parallel eager select for related objects.
selectEagerParallel(SelectExecutor, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
selectEagerParallel(SelectExecutor, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
selectEagerParallel(SelectExecutor, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.meta.strats.StoreCollectionFieldStrategy
 
selectElement(Select, ClassMapping, JDBCStore, JDBCFetchConfiguration, int, Joins) - Method in interface org.apache.openjpa.jdbc.meta.strats.LRSCollectionFieldStrategy
Implement this method to select the elements of this field for the given element mapping from LRSCollectionFieldStrategy.getIndependentElementMappings(boolean) (or null).
selectElement(Select, ClassMapping, JDBCStore, JDBCFetchConfiguration, int, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationCollectionInverseKeyFieldStrategy
 
selectElement(Select, ClassMapping, JDBCStore, JDBCFetchConfiguration, int, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationCollectionTableFieldStrategy
 
selectElement(Select, ClassMapping, JDBCStore, JDBCFetchConfiguration, int, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyInverseKeyFieldStrategy
 
selectElement(Select, ClassMapping, JDBCStore, JDBCFetchConfiguration, int, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyTableFieldStrategy
 
selectElement(Select, ClassMapping, JDBCStore, JDBCFetchConfiguration, int, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.StoreCollectionFieldStrategy
Implement this method to select the elements of this field for the given element mapping from ContainerFieldStrategy.getIndependentElementMappings(boolean) (or null).
SelectExecutor - Interface in org.apache.openjpa.jdbc.sql
Interface for configuring and executing a SQL select.
selectForUpdate(Select, int) - Method in interface org.apache.openjpa.jdbc.kernel.JDBCLockManager
Return whether to issue the given select FOR UPDATE, depending on the capabilities of the dictionary and the fetch configuration.
selectForUpdate(Select, int) - Method in class org.apache.openjpa.jdbc.kernel.PessimisticLockManager
 
selectIdentifier(Column) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
selectIdentifier(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
selectIdentifier(Column[]) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
selectIdentifier(Column[], Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
selectIdentifier(ClassMapping, int, JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
selectIdentifier(ClassMapping, int, JDBCStore, JDBCFetchConfiguration, int, Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
selectIdentifier(Column) - Method in interface org.apache.openjpa.jdbc.sql.Select
Select the given column as one that can be used to get a count of distinct matches.
selectIdentifier(Column, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
Select the given column as one that can be used to get a count of distinct matches.
selectIdentifier(Column[]) - Method in interface org.apache.openjpa.jdbc.sql.Select
Select the given columns as ones that can be used to get a count of distinct matches.
selectIdentifier(Column[], Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
Select the given columns as ones that can be used to get a count of distinct matches.
selectIdentifier(ClassMapping, int, JDBCStore, JDBCFetchConfiguration, int) - Method in interface org.apache.openjpa.jdbc.sql.Select
Select the columns of the given mapping, possibly including subclasses.
selectIdentifier(ClassMapping, int, JDBCStore, JDBCFetchConfiguration, int, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
Select the columns of the given mapping, possibly including subclasses.
selectIdentifier(Column) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
selectIdentifier(Column, Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
selectIdentifier(Column[]) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
selectIdentifier(Column[], Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
selectIdentifier(ClassMapping, int, JDBCStore, JDBCFetchConfiguration, int) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
selectIdentifier(ClassMapping, int, JDBCStore, JDBCFetchConfiguration, int, Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
SelectImpl - Class in org.apache.openjpa.jdbc.sql
Standard Select implementation.
SelectImpl(JDBCConfiguration) - Constructor for class org.apache.openjpa.jdbc.sql.SelectImpl
Constructor.
SelectImpl.SelectResult - Class in org.apache.openjpa.jdbc.sql
A Result implementation wrapped around this select.
SelectImpl.SelectResult(Connection, Statement, ResultSet, DBDictionary) - Constructor for class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
Constructor.
selectKey(Select, ClassMapping, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Joins) - Method in interface org.apache.openjpa.jdbc.meta.strats.LRSMapFieldStrategy
Implement this method to select the keys of this field.
selectKey(Select, ClassMapping, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapInverseKeyFieldStrategy
 
selectKey(Select, ClassMapping, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapTableFieldStrategy
 
selectPlaceholder(String) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
selectPlaceholder(String) - Method in interface org.apache.openjpa.jdbc.sql.Select
Select the given SQL as a placeholder for a UNION element.
selectPlaceholder(String) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
selectPrimaryKey(ClassMapping) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
selectPrimaryKey(ClassMapping, Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
selectPrimaryKey(ClassMapping) - Method in interface org.apache.openjpa.jdbc.sql.Select
Select the primary key columns of the given mapping, joining to superclasses as necessary to get all columns needed to construct an object id.
selectPrimaryKey(ClassMapping, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
Select the primary key columns of the given mapping, joining to superclasses as necessary to get all columns needed to construct an object id.
selectPrimaryKey(ClassMapping) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
selectPrimaryKey(ClassMapping, Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
SelectResultObjectProvider - Class in org.apache.openjpa.jdbc.kernel
Abstract provider implementation wrapped around a Select.
SelectResultObjectProvider(SelectExecutor, JDBCStore, JDBCFetchConfiguration) - Constructor for class org.apache.openjpa.jdbc.kernel.SelectResultObjectProvider
Constructor.
selectValue(Select, ClassMapping, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Joins) - Method in interface org.apache.openjpa.jdbc.meta.strats.LRSMapFieldStrategy
Implement this method to select the values of this field.
selectValue(Select, ClassMapping, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapInverseKeyFieldStrategy
 
selectValue(Select, ClassMapping, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration, Joins) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapTableFieldStrategy
 
sels - Variable in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
seq - Variable in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq.Status
 
Seq - Interface in org.apache.openjpa.kernel
Internal OpenJPA sequence interface.
seqPlugin - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
Sequence - Class in org.apache.openjpa.jdbc.schema
Represents a database sequence.
Sequence() - Constructor for class org.apache.openjpa.jdbc.schema.Sequence
Default constructor.
Sequence(String, Schema) - Constructor for class org.apache.openjpa.jdbc.schema.Sequence
Constructor.
SEQUENCE - Static variable in class org.apache.openjpa.meta.ValueStrategies
"sequence" value strategy.
SequenceMapping - Class in org.apache.openjpa.jdbc.meta
Specialization of sequence metadata for ORM.
SequenceMapping(String, MappingRepository) - Constructor for class org.apache.openjpa.jdbc.meta.SequenceMapping
 
SequenceMetaData - Class in org.apache.openjpa.meta
Metadata about a named sequence.
SequenceMetaData(String, MetaDataRepository) - Constructor for class org.apache.openjpa.meta.SequenceMetaData
Constructor; supply sequence name.
SequenceMetaData.SequenceFactory - Interface in org.apache.openjpa.meta
Allow facades to supply adapters from a spec sequence type to the OpenJPA sequence type.
sequences - Variable in class org.apache.openjpa.jdbc.meta.MappingTool.Flags
 
sequences - Variable in class org.apache.openjpa.jdbc.schema.SchemaTool.Flags
 
SeqValue - Class in org.apache.openjpa.conf
Value type used to represent a sequence.
SeqValue(String) - Constructor for class org.apache.openjpa.conf.SeqValue
 
SERIALIZABLE - Static variable in interface org.apache.openjpa.enhance.PersistenceCapable
 
Serialization - Class in org.apache.openjpa.util
Helper class to serialize and deserialize persistent objects, subtituting oids into the serialized stream and subtituting the persistent objects back during deserialization.
Serialization() - Constructor for class org.apache.openjpa.util.Serialization
 
serialize(Collection) - Method in class org.apache.openjpa.jdbc.schema.XMLSchemaSerializer
 
serialize(Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return the serialized bytes for the given object.
serialize(int) - Method in interface org.apache.openjpa.lib.meta.MetaDataSerializer
Serialize the current set of objects to the files from which they were parsed.
serialize(Map, int) - Method in interface org.apache.openjpa.lib.meta.MetaDataSerializer
Serialize the current set of objects to the files from which they were parsed.
serialize(File, int) - Method in interface org.apache.openjpa.lib.meta.MetaDataSerializer
Serialize the current set of objects to the given file.
serialize(Writer, int) - Method in interface org.apache.openjpa.lib.meta.MetaDataSerializer
Serialize the current set of objects to the given stream.
serialize(int) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
 
serialize(Map, int) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
 
serialize(File, int) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
 
serialize(Writer, int) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
 
serialize(Result, int) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
Serialize the current set of objects to the given result.
serialize(ContentHandler, int) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
Serilize the current set of objects to a series of SAX events on the given handler.
serialize(Collection) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
Serialize the given set of objects.
serialize(MetaDataSerializer, Map, int) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Tell the given serialier to write its metadatas.
serialize(Collection) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
 
serialize(Object, StoreContext) - Static method in class org.apache.openjpa.util.Serialization
Serialize a value that might contain persistent objects.
serializeAttributeOverride(FieldMetaData, FieldMetaData) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer
 
serializeAttributeOverride(FieldMetaData, FieldMetaData) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Always returns false by default.
serializeAttributeOverrideMappingContent(FieldMetaData, FieldMetaData) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer
 
serializeAttributeOverrideMappingContent(FieldMetaData, FieldMetaData) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Serialize attribute override mapping content.
serializeClass(ClassMetaData, boolean) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer
 
serializeClass(ClassMetaData, boolean) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Serialize class metadata.
serializeClassMappingContent(ClassMetaData) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer
 
serializeClassMappingContent(ClassMetaData) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Serialize class mapping content.
serializeFieldMappingContent(FieldMetaData, PersistenceStrategy) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer
 
serializeFieldMappingContent(FieldMetaData, PersistenceStrategy) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Serialize field mapping content; this will be called before #serializeValueMappingContent.
serializeInheritanceContent(ClassMetaData) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer
 
serializeInheritanceContent(ClassMetaData) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Serialize inheritance content.
serializeProperties(Map) - Static method in class org.apache.openjpa.lib.conf.Configurations
Turn a set of properties into a comma-separated string.
serializeQueryMappings(ClassMetaData) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer
 
serializeQueryMappings(ClassMetaData) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Serialize query mappings.
serializeSequence(SequenceMetaData) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer
 
serializeSequence(SequenceMetaData) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Serialize sequence metadata.
serializeSystemMappingElement(Object) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer
 
serializeSystemMappingElement(Object) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Serialize unknown mapping element at system level.
serializing() - Method in interface org.apache.openjpa.enhance.StateManager
Callback to prepare instance for serialization.
serializing() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
serializing() - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
serializing() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
serializing() - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
Services - Class in org.apache.openjpa.lib.util
Utility classes to locate services, as defined in the Jar File Specification.
Services() - Constructor for class org.apache.openjpa.lib.util.Services
 
set(ConfigurationProvider, String) - Static method in class org.apache.openjpa.conf.BrokerFactoryValue
Set the value of this property in the given provider.
set(ValueMapping, Object, JDBCStore, Row, Column[], ColumnIO, boolean) - Static method in class org.apache.openjpa.jdbc.meta.strats.HandlerStrategies
Set the given value into the given row.
set(Object) - Method in class org.apache.openjpa.kernel.DelegatingResultList.DelegatingListIterator
 
set(int, Object) - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
set(int, Object) - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
set(boolean) - Method in class org.apache.openjpa.lib.conf.BooleanValue
The internal value.
set(double) - Method in class org.apache.openjpa.lib.conf.DoubleValue
The internal value.
set(File) - Method in class org.apache.openjpa.lib.conf.FileValue
The internal value.
set(int) - Method in class org.apache.openjpa.lib.conf.IntValue
The internal value.
set(Object) - Method in class org.apache.openjpa.lib.conf.ObjectValue
The internal value.
set(Object, boolean) - Method in class org.apache.openjpa.lib.conf.ObjectValue
The internal value.
set(Object, boolean) - Method in class org.apache.openjpa.lib.conf.PluginValue
 
set(String[]) - Method in class org.apache.openjpa.lib.conf.StringListValue
The internal value.
set(String) - Method in class org.apache.openjpa.lib.conf.StringValue
The internal value.
set(int, Object) - Method in class org.apache.openjpa.lib.rop.AbstractResultList
 
set(int, Object) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
set(int, Object) - Method in class org.apache.openjpa.util.ProxyArrayList
 
set(int, int) - Method in class org.apache.openjpa.util.ProxyGregorianCalendar
 
set(int, Object) - Method in class org.apache.openjpa.util.ProxyLinkedList
 
set(int, Object) - Method in class org.apache.openjpa.util.ProxyVector
 
SET_ATTACH - Static variable in interface org.apache.openjpa.enhance.StateManager
 
SET_ATTACH - Static variable in interface org.apache.openjpa.kernel.OpenJPAStateManager
The field is being attached by a detached state manager; the value is from the detached instance.
SET_REMOTE - Static variable in interface org.apache.openjpa.enhance.StateManager
 
SET_REMOTE - Static variable in interface org.apache.openjpa.kernel.OpenJPAStateManager
The remote broker framework is setting the field on the server.
SET_USER - Static variable in interface org.apache.openjpa.enhance.StateManager
 
SET_USER - Static variable in interface org.apache.openjpa.kernel.OpenJPAStateManager
A user is setting the field.
setAccessType(int) - Method in class org.apache.openjpa.meta.ClassMetaData
The access type used by this class.
setAccessUnloaded(boolean) - Method in class org.apache.openjpa.conf.DetachOptions
Whether to allow access to unloaded detached fields.
setAction(MetaDataToolTask.Action) - Method in class org.apache.openjpa.ant.MetaDataToolTask
Set the tool action.
setAction(MappingToolTask.Action) - Method in class org.apache.openjpa.jdbc.ant.MappingToolTask
Set the enumerated MappingTool action type.
setAction(SchemaToolTask.Action) - Method in class org.apache.openjpa.jdbc.ant.SchemaToolTask
Set the enumerated SchemaTool action type.
setAction(int) - Method in class org.apache.openjpa.kernel.InverseManager
Set the action constant to use during relationship checking.
setAction(String) - Method in class org.apache.openjpa.kernel.InverseManager
Set the action string to use during relationship checking.
setAddDefaultConstructor(boolean) - Method in class org.apache.openjpa.ant.PCEnhancerTask
Set whether or not the enhancer should add a no-args constructor to any PC that does not have a no-args constructor.
setAddDefaultConstructor(boolean) - Method in class org.apache.openjpa.enhance.PCEnhancer
A boolean indicating whether the enhancer should add a no-args constructor if one is not already present in the class.
setAddNullIndicator(boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Whether to add a synthetic null indicator column to embedded mappings by default.
setAddresses(String) - Method in class org.apache.openjpa.event.TCPRemoteCommitProvider
Sets the list of addresses of peers to which this provider will send events to.
setAddWhitespaceAfterDelimiter(boolean) - Method in class org.apache.openjpa.lib.util.FormatPreservingProperties
If set to true, this properties object will add a space after the delimiter character(if the delimiter is not the space character).
setAggregate(boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
setAggregate(boolean) - Method in interface org.apache.openjpa.jdbc.sql.Select
Set to true for aggregate selects.
setAggregate(boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
setAggregateListeners(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
A comma-separted list of the plugin strings of the query AggregateListeners to use.
setAggregateListeners(AggregateListener[]) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Set the query function listeners.
setAggregateListeners(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setAggregateListeners(AggregateListener[]) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setAlias(String, String) - Method in class org.apache.openjpa.lib.conf.Value
Replaces an existing alias, or adds the given alias to the front of the alias list if it does not already exist.
setAlias(String, String, String[]) - Method in class org.apache.openjpa.lib.conf.Value
Set an alias into a current alias list, returning the new list.
setAliases(String[]) - Method in class org.apache.openjpa.lib.conf.Value
Aliases for the value in the form key1, value1, key2, value2, ...
setAliasListComprehensive(boolean) - Method in class org.apache.openjpa.lib.conf.Value
Whether or not the alias list defines all possible settings for this value.
setAllocate(int) - Method in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
 
setAllocate(int) - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
Return the number of sequences to allocate for each update of the sequence table.
setAllocate(int) - Method in class org.apache.openjpa.jdbc.schema.Sequence
The sequence's cache size.
setAllocate(int) - Method in class org.apache.openjpa.meta.SequenceMetaData
Sequence values to allocate, or -1 for default.
setAllowDuplicates(boolean) - Method in class org.apache.openjpa.lib.util.FormatPreservingProperties
If set to true, duplicate properties are allowed, and the last property setting in the input will overwrite any previous settings.
setAllowsMultipleMethodsForSameCallback(boolean) - Method in class org.apache.openjpa.persistence.PersistenceMetaDataDefaults
Flags if multiple methods of the same class can handle the same callback event.
setAnnotationParser(AnnotationPersistenceMetaDataParser) - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
Set the metadata parser.
setAnnotationParser(AnnotationPersistenceMetaDataParser) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
The annotation parser.
setArray(PreparedStatement, int, Array, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setArray(Column, Array) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setArray(Column, Array) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setArray(int, Array) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setArray(int, Array) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setAsciiStream(PreparedStatement, int, InputStream, int, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setAsciiStream(Column, InputStream, int) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setAsciiStream(Column, InputStream, int) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setAsciiStream(int, InputStream, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setAsciiStream(String, InputStream, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setAsciiStream(int, InputStream, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setAssertAllowedType(boolean) - Method in class org.apache.openjpa.util.ProxyManagerImpl
Whether to perform runtime checks to ensure that all elements added to collection and map proxies are the proper element/key/value type as defined by the metadata.
setAuthentication(String, String) - Method in class org.apache.openjpa.kernel.BrokerImpl
Set the persistence manager's authentication.
setAutoAssigned(boolean) - Method in class org.apache.openjpa.jdbc.schema.Column
Whether this column is auto-incrementing.
setAutoAssignedValue(OpenJPAStateManager, JDBCStore, Column, Object) - Method in class org.apache.openjpa.jdbc.meta.DelegatingJoinable
 
setAutoAssignedValue(OpenJPAStateManager, JDBCStore, Column, Object) - Method in interface org.apache.openjpa.jdbc.meta.Joinable
Use the given auto-assigned value to set this join value's field on the given instance.
setAutoAssignedValue(OpenJPAStateManager, JDBCStore, Column, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
setAutoAssignedValue(OpenJPAStateManager, JDBCStore, Column, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
setAutoAssignedValue(OpenJPAStateManager, JDBCStore, Column, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
setAutoAssignedValue(OpenJPAStateManager, JDBCStore, Column, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
setAutoClear(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Whether instances clear their state when entering a transaction.
setAutoClear(int) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Whether instances clear their state when entering a transaction.
setAutoClear(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setAutoClear(int) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setAutoClear(int) - Method in interface org.apache.openjpa.kernel.Broker
Whether objects clear when entering transactions.
setAutoClear(int) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
setAutoClear(int) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
setAutoClear(int) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
setAutoClear(int) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether to clear state when entering a transaction.
setAutoCommit(Boolean) - Method in class org.apache.openjpa.lib.jdbc.ConfiguringConnectionDecorator
Whether auto commit should be on.
setAutoCommit(boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
setAutoDetach(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
A comma-separated list of events which trigger auto-detachment in place of managed states.
setAutoDetach(int) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The AutoDetach flags.
setAutoDetach(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setAutoDetach(int) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setAutoDetach(int) - Method in interface org.apache.openjpa.kernel.Broker
Bit flags marked in AutoDetach which indicate when persistent managed objects should be automatically detached in-place.
setAutoDetach(int, boolean) - Method in interface org.apache.openjpa.kernel.Broker
Bit flags marked in AutoDetach which indicate when persistent managed objects should be automatically detached in-place.
setAutoDetach(int) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
setAutoDetach(int, boolean) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
setAutoDetach(int) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
setAutoDetach(int, boolean) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
setAutoDetach(int) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
setAutoDetach(int, boolean) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
setAutoDetach(int) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Bit flags marked in AutoDetach which indicate when persistent managed objects should be automatically detached in-place.
setAutoDetach(int, boolean) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Bit flags marked in AutoDetach which indicate when persistent managed objects should be automatically detached in-place.
setAutoDistinct(boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
setAutoDistinct(boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
setAutoDistinct(boolean) - Method in interface org.apache.openjpa.jdbc.sql.SelectExecutor
Whether to automatically make results distinct when relational joins would otherwise introduce duplicates.
setAutoDistinct(boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
setAutoOff(boolean) - Method in class org.apache.openjpa.util.AbstractChangeTracker
Whether to automatically stop tracking when the number of changes exceeds the container size.
setBase(Class) - Method in class org.apache.openjpa.meta.InheritanceComparator
Set the least-derived type possible; defaults to Object.class.
setBaseClassStrategy(String) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default base class strategy alias.
setBaseMapping(ClassMapping) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
setBaseMapping(ClassMapping) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
setBaseMapping(ClassMapping) - Method in interface org.apache.openjpa.jdbc.sql.Result
If this is the result of a UNION used to select a hierarchy of mappings, the base mapping represented by the current row.
setBigDecimal(PreparedStatement, int, BigDecimal, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setBigDecimal(PreparedStatement, int, BigDecimal, Column) - Method in class org.apache.openjpa.jdbc.sql.HSQLDictionary
 
setBigDecimal(Column, BigDecimal) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setBigDecimal(Column, BigDecimal) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setBigDecimal(int, BigDecimal) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setBigDecimal(String, BigDecimal) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setBigDecimal(int, BigDecimal) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setBigInteger(PreparedStatement, int, BigInteger, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setBigInteger(Column, BigInteger) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setBigInteger(Column, BigInteger) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setBigInteger(PreparedStatement, int, BigInteger, Column) - Method in class org.apache.openjpa.jdbc.sql.SybaseDictionary
 
setBinaryStream(PreparedStatement, int, InputStream, int, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setBinaryStream(Column, InputStream, int) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setBinaryStream(Column, InputStream, int) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setBinaryStream(int, InputStream, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setBinaryStream(String, InputStream, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setBinaryStream(int, InputStream, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setBlob(PreparedStatement, int, Blob, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setBlob(Column, Blob) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setBlob(Column, Blob) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setBlob(int, Blob) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setBlob(int, Blob) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setBlobAsObject(boolean) - Method in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
Set whether to represent blob columns as Java objects rather than byte[] fields.
setBlobAsObject(boolean) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Whether to reverse-map blob columns as containing serialized Java objects, rather than the default of using a byte[] field.
setBlobObject(PreparedStatement, int, Object, Column, JDBCStore) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setBoolean(int, boolean) - Method in interface org.apache.openjpa.enhance.DynamicStorage
Set the boolean at the given index.
setBoolean(PreparedStatement, int, boolean, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setBoolean(PreparedStatement, int, boolean, Column) - Method in class org.apache.openjpa.jdbc.sql.InformixDictionary
 
setBoolean(PreparedStatement, int, boolean, Column) - Method in class org.apache.openjpa.jdbc.sql.PostgresDictionary
 
setBoolean(Column, boolean) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setBoolean(Column, boolean) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setBoolean(int, boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setBoolean(String, boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setBoolean(int, boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setBraceAtSameTabLevel(boolean) - Method in class org.apache.openjpa.lib.util.CodeFormat
Whether to place braces at the same tab level as the code within the block.
setBraceOnSameLine(boolean) - Method in class org.apache.openjpa.lib.util.CodeFormat
Whether to place opening braces on the same line as the block declaration, or on the next line.
setBrokerFactory(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The BrokerFactory class to use.
setBrokerFactory(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setBrokerFactory(BrokerFactory) - Method in class org.apache.openjpa.persistence.EntityManagerFactoryImpl
Delegate must be provided before use.
setBrokerImpl(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The plugin string of the BrokerImpl extension to create.
setBrokerImpl(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setByte(int, byte) - Method in interface org.apache.openjpa.enhance.DynamicStorage
Set the byte at the given index.
setByte(PreparedStatement, int, byte, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setByte(Column, byte) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setByte(Column, byte) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setByte(int, byte) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setByte(String, byte) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setByte(int, byte) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setBytecodeWriter(BytecodeWriter) - Method in class org.apache.openjpa.enhance.PCEnhancer
Set the BytecodeWriter to write the bytecode to or null if none.
setBytes(PreparedStatement, int, byte[], Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setBytes(Column, byte[]) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setBytes(Column, byte[]) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setBytes(int, byte[]) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setBytes(String, byte[]) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setBytes(int, byte[]) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setCacheSize(int) - Method in class org.apache.openjpa.datacache.ConcurrentDataCache
Sets the maximum number of unpinned objects to keep hard references to.
setCacheSize(int) - Method in class org.apache.openjpa.datacache.ConcurrentQueryCache
Sets the maximum number of unpinned objects to keep hard references to.
setCacheSize(int) - Method in class org.apache.openjpa.util.CacheMap
The maximum number of hard references to maintain, or -1 for no limit.
setCaching(boolean) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Whether parsed resource names are cached to avoid duplicate parsing.
setCalendar(PreparedStatement, int, Calendar, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setCalendar(Column, Calendar) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setCalendar(Column, Calendar) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setCallbackMode(int) - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
 
setCallbackMode(int, boolean) - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
 
setCandidateCollection(Collection) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
setCandidateCollection(Collection) - Method in interface org.apache.openjpa.kernel.Query
Set a collection of candidates.
setCandidateCollection(Collection) - Method in class org.apache.openjpa.kernel.QueryImpl
 
setCandidateCollection(Collection) - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Set a collection of candidates.
setCandidateCollection(Collection) - Method in class org.apache.openjpa.persistence.QueryImpl
 
setCandidateExtent(Extent) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
setCandidateExtent(Extent) - Method in interface org.apache.openjpa.kernel.Query
Set the candidate extent.
setCandidateExtent(Extent) - Method in class org.apache.openjpa.kernel.QueryImpl
 
setCandidateType(Class, boolean) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
setCandidateType(Class, boolean) - Method in interface org.apache.openjpa.kernel.QueryContext
Set the candidate type.
setCandidateType(Class, boolean) - Method in class org.apache.openjpa.kernel.QueryImpl
 
setCandidateType(Class) - Method in class org.apache.openjpa.meta.QueryMetaData
The query result class, or null if none.
setCanForeignKey(boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
The user can mark columns as explicitly not having a foreign key.
setCanIndex(boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
The user can mark columns as explicitly non-indexable.
setCanIndicateNull(boolean) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingInfo
Whether user has explicitly turned null indicator column off.
setCanOrderColumn(boolean) - Method in class org.apache.openjpa.jdbc.meta.FieldMappingInfo
Whether we can have an ordering column.
setCanUnique(boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
The user can mark columns as explicitly not having a unique constraint.
setCascadeAttach(int) - Method in class org.apache.openjpa.meta.FieldMetaData
 
setCascadeAttach(int) - Method in interface org.apache.openjpa.meta.ValueMetaData
Cascade behavior for attach operation.
setCascadeAttach(int) - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
setCascadeDelete(int) - Method in class org.apache.openjpa.meta.FieldMetaData
 
setCascadeDelete(int) - Method in interface org.apache.openjpa.meta.ValueMetaData
Cascade behavior for deletion.
setCascadeDelete(int) - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
setCascadePersist(int) - Method in class org.apache.openjpa.meta.FieldMetaData
 
setCascadePersist(int) - Method in interface org.apache.openjpa.meta.ValueMetaData
Cascade behavior for persist operation.
setCascadePersist(int) - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
setCascadeRefresh(int) - Method in class org.apache.openjpa.meta.FieldMetaData
 
setCascadeRefresh(int) - Method in interface org.apache.openjpa.meta.ValueMetaData
Cascade behavior for refresh operation.
setCascadeRefresh(int) - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
setCascades(FieldMetaData) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Set the cached cascades into the field.
setCatalog(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
setCause(Throwable) - Method in exception org.apache.openjpa.util.OpenJPAException
The first nested throwable.
setChannel(String) - Method in class org.apache.openjpa.event.LogOrphanedKeyAction
The channel to log to.
setChannel(String) - Method in class org.apache.openjpa.lib.log.LogFactoryImpl.LogImpl
 
setChar(int, char) - Method in interface org.apache.openjpa.enhance.DynamicStorage
Set the char at the given index.
setChar(PreparedStatement, int, char, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setChar(Column, char) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setChar(Column, char) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setCharacterStream(PreparedStatement, int, Reader, int, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setCharacterStream(Column, Reader, int) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setCharacterStream(Column, Reader, int) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setCharacterStream(int, Reader, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setCharacterStream(String, Reader, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setCharacterStream(int, Reader, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setClassLoader(ClassLoader) - Method in interface org.apache.openjpa.jdbc.schema.DriverDataSource
JDBC password.
setClassLoader(ClassLoader) - Method in class org.apache.openjpa.jdbc.schema.SimpleDriverDataSource
 
setClassLoader(ClassLoader) - Method in class org.apache.openjpa.lib.meta.ClassArgParser
The class loader with which to load parsed classes.
setClassLoader(ClassLoader) - Method in interface org.apache.openjpa.lib.meta.MetaDataParser
The classloader to use to resolve resources, or null for impl-defined default.
setClassLoader(ClassLoader) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Classloader to use for class name resolution.
setClassLoaders(MultiClassLoader) - Method in class org.apache.openjpa.lib.util.MultiClassLoader
Set the class loaders of this loader to those of the given loader.
setClassMapping(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
setClassMapping(ClassMapping) - Method in interface org.apache.openjpa.jdbc.meta.ClassStrategy
Set the class mapping using this strategy.
setClassMapping(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractClassStrategy
 
setClassMapping(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.NoneClassStrategy
 
setClassName(String) - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
The described class name.
setClassName(String) - Method in class org.apache.openjpa.lib.conf.PluginValue
The plugin class name.
setClassNames(String[]) - Method in class org.apache.openjpa.lib.conf.PluginListValue
The plugin class names.
setClasspath(Path) - Method in class org.apache.openjpa.lib.ant.AbstractTask
 
setClasspathScan(Collection) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Set of classpath directories or jars to scan for metadata supplied by user.
setClasspathScan(String) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Set of classpath directories or jars to scan for metadata supplied by user via auto-configuration.
setClassResolver(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The plugin string for the ClassResolver to use for custom class loading.
setClassResolver(ClassResolver) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The ClassResolver to use.
setClassResolver(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setClassResolver(ClassResolver) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setClauseIndent(String) - Method in class org.apache.openjpa.lib.jdbc.SQLFormatter
 
setClob(PreparedStatement, int, Clob, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setClob(Column, Clob) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setClob(Column, Clob) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setClob(int, Clob) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setClob(int, Clob) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setClobString(PreparedStatement, int, String, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setCloseConnection(boolean) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
Whether to close the backing connection when this result is closed.
setCloseOnManagedCommit(boolean) - Method in class org.apache.openjpa.conf.Compatibility
Whether to close the broker when the managed transaction commits.
setCodeFormat(CodeFormat) - Method in class org.apache.openjpa.enhance.ApplicationIdTool
Set the code formatter for the generated Java code.
setCodeFormat(CodeFormat) - Method in class org.apache.openjpa.enhance.CodeGenerator
Set the code formatter for the generated Java code.
setCodeFormat(CodeFormat) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Set the code formatter for the generated Java code.
setColumnIO(ColumnIO) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
I/O information on the key columns / join key.
setColumnIO(ColumnIO) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
I/O information on the discriminator columns.
setColumnIO(ColumnIO) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
setColumnIO(ColumnIO) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
I/O for the columns created by the last call to MappingInfo.createColumns(org.apache.openjpa.meta.MetaDataContext, java.lang.String, org.apache.openjpa.jdbc.schema.Column[], org.apache.openjpa.jdbc.schema.Table, boolean), or for the foreign key created by the last call to MappingInfo.createForeignKey(org.apache.openjpa.meta.MetaDataContext, java.lang.String, java.util.List, org.apache.openjpa.jdbc.meta.MappingInfo.ForeignKeyDefaults, org.apache.openjpa.jdbc.schema.Table, org.apache.openjpa.jdbc.meta.ClassMapping, org.apache.openjpa.jdbc.meta.ClassMapping, boolean, boolean).
setColumnIO(ColumnIO) - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
I/O information on the foreign key, or columns if this value doesn't have a key.
setColumnIO(ColumnIO) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
setColumnIO(ColumnIO) - Method in class org.apache.openjpa.jdbc.meta.Version
I/O information on the version columns.
setColumnName(String) - Method in class org.apache.openjpa.jdbc.schema.Constraint
Set the column's name.
setColumns(Column[]) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
Columns used by this Discriminator.
setColumns(Column[]) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
setColumns(List) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Raw column data.
setColumns(Column[]) - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
The columns that hold the data for this value.
setColumns(Column[]) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
setColumns(Column[]) - Method in class org.apache.openjpa.jdbc.meta.Version
Columns used for versioning.
setColumns(Column[]) - Method in class org.apache.openjpa.jdbc.schema.LocalConstraint
Set the columns the constraint spans.
setColumns(FieldMapping, MappingInfo, List<Column>, int) - Method in class org.apache.openjpa.persistence.jdbc.AnnotationPersistenceMappingParser
Set the given columns as the columns for fm.
setComments(String[]) - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
 
setComments(String[]) - Method in class org.apache.openjpa.jdbc.meta.FieldMappingInfo
 
setComments(String[]) - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping
 
setComments(String[]) - Method in interface org.apache.openjpa.lib.xml.Commentable
Set comments.
setComments(String[]) - Method in class org.apache.openjpa.meta.ClassMetaData
 
setComments(String[]) - Method in class org.apache.openjpa.meta.FieldMetaData
 
setComments(String[]) - Method in class org.apache.openjpa.meta.NonPersistentMetaData
 
setComments(String[]) - Method in class org.apache.openjpa.meta.QueryMetaData
 
setComments(String[]) - Method in class org.apache.openjpa.meta.SequenceMetaData
 
setCompatibility(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Backwards compatibility options.
setCompatibility(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setConfiguration(Configuration) - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
setConfiguration(Configuration) - Method in class org.apache.openjpa.datacache.AbstractQueryCache
 
setConfiguration(Configuration) - Method in class org.apache.openjpa.ee.AutomaticManagedRuntime
 
setConfiguration(Configuration) - Method in class org.apache.openjpa.ee.InvocationManagedRuntime
 
setConfiguration(Configuration) - Method in class org.apache.openjpa.ee.WASManagedRuntime
Caches a copy of the configuration.
setConfiguration(Configuration) - Method in class org.apache.openjpa.event.AbstractRemoteCommitProvider
 
setConfiguration(Configuration) - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSavepointManager
 
setConfiguration(Configuration) - Method in class org.apache.openjpa.jdbc.kernel.AbstractUpdateManager
 
setConfiguration(Configuration) - Method in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
 
setConfiguration(Configuration) - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
 
setConfiguration(Configuration) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
setConfiguration(Properties) - Method in class org.apache.openjpa.jdbc.meta.PropertiesReverseCustomizer
 
setConfiguration(Properties) - Method in interface org.apache.openjpa.jdbc.meta.ReverseCustomizer
Set configuration properties given by the user.
setConfiguration(Configuration) - Method in class org.apache.openjpa.jdbc.schema.DynamicSchemaFactory
 
setConfiguration(Configuration) - Method in class org.apache.openjpa.jdbc.schema.FileSchemaFactory
 
setConfiguration(Configuration) - Method in class org.apache.openjpa.jdbc.schema.LazySchemaFactory
 
setConfiguration(Configuration) - Method in class org.apache.openjpa.jdbc.schema.TableSchemaFactory
 
setConfiguration(Configuration) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
 
setConfiguration(Configuration) - Method in class org.apache.openjpa.jdbc.sql.SQLFactoryImpl
 
setConfiguration(Configuration) - Method in class org.apache.openjpa.kernel.InverseManager
 
setConfiguration(Configuration) - Method in interface org.apache.openjpa.lib.conf.Configurable
Invoked prior to setting bean properties.
setConfiguration(Configuration) - Method in class org.apache.openjpa.meta.MetaDataRepository
 
setConfiguration(Configuration) - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
 
setConfiguration(Configuration) - Method in class org.apache.openjpa.util.ProxyManagerImpl
 
setConnection2DriverName(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Class name of the non-XA connection driver.
setConnection2DriverName(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setConnection2Password(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The password for the non-XA data store connection.
setConnection2Password(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setConnection2Properties(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
These properties provide any additional information needed to establish non-XA connections.
setConnection2Properties(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setConnection2URL(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The URL for the non-XA data store connection.
setConnection2URL(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setConnection2UserName(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The user name for the non-XA data store connection.
setConnection2UserName(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setConnectionDecorators(String) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
A comma-separated list of the ConnectionDecorator for adding functionality to JDBC connections.
setConnectionDecorators(ConnectionDecorator[]) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The ConnectionDecorators to use.
setConnectionDecorators(String) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setConnectionDecorators(ConnectionDecorator[]) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setConnectionDriverName(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Class name of the connection driver.
setConnectionDriverName(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setConnectionDriverName(String) - Method in interface org.apache.openjpa.jdbc.schema.DriverDataSource
Driver class name.
setConnectionDriverName(String) - Method in class org.apache.openjpa.jdbc.schema.SimpleDriverDataSource
 
setConnectionFactory(Object) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The connection factory.
setConnectionFactory(Object) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setConnectionFactory(Object) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setConnectionFactory2(Object) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The non-XA connection factory.
setConnectionFactory2(Object) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setConnectionFactory2(Object) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setConnectionFactory2Name(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The name for the second data store connection factory.
setConnectionFactory2Name(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setConnectionFactory2Properties(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Configuration properties for the non-XA connection factory.
setConnectionFactory2Properties(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setConnectionFactoryMode(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The mode of the connection factory in use.
setConnectionFactoryMode(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setConnectionFactoryModeManaged(boolean) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Whether connections are automatically enlisted in global transactions.
setConnectionFactoryModeManaged(boolean) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setConnectionFactoryName(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The name for the data store connection factory.
setConnectionFactoryName(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setConnectionFactoryProperties(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Configuration properties for the connection factory.
setConnectionFactoryProperties(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setConnectionFactoryProperties(Properties) - Method in interface org.apache.openjpa.jdbc.schema.DriverDataSource
Configuration of datasource properties.
setConnectionFactoryProperties(Properties) - Method in class org.apache.openjpa.jdbc.schema.SimpleDriverDataSource
 
setConnectionPassword(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The password for the data store connection.
setConnectionPassword(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setConnectionPassword(String) - Method in interface org.apache.openjpa.jdbc.schema.DriverDataSource
JDBC password.
setConnectionPassword(String) - Method in class org.apache.openjpa.jdbc.schema.SimpleDriverDataSource
 
setConnectionProperties(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
These properties provide any additional information needed to establish connections.
setConnectionProperties(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setConnectionProperties(Properties) - Method in interface org.apache.openjpa.jdbc.schema.DriverDataSource
Configuration of connection.
setConnectionProperties(Properties) - Method in class org.apache.openjpa.jdbc.schema.SimpleDriverDataSource
 
setConnectionRetainMode(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Specifies the behavior of the broker with respect to data store connections.
setConnectionRetainMode(int) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Set the connection retain mode as one of the following symbolic constants: ConnectionRetainModes.CONN_RETAIN_ALWAYS ConnectionRetainModes.CONN_RETAIN_TRANS ConnectionRetainModes.CONN_RETAIN_DEMAND
setConnectionRetainMode(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setConnectionRetainMode(int) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setConnectionURL(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The URL for the data store connection.
setConnectionURL(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setConnectionURL(String) - Method in interface org.apache.openjpa.jdbc.schema.DriverDataSource
JDBC URL.
setConnectionURL(String) - Method in class org.apache.openjpa.jdbc.schema.SimpleDriverDataSource
 
setConnectionUserName(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The user name for the data store connection.
setConnectionUserName(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setConnectionUserName(String) - Method in interface org.apache.openjpa.jdbc.schema.DriverDataSource
JDBC user name.
setConnectionUserName(String) - Method in class org.apache.openjpa.jdbc.schema.SimpleDriverDataSource
 
setConstantJoins(Object[], Column[]) - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Set the foreign key's constant joins.
setConstantJoins(Column[], Object[]) - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Set the foreign key's constant joins.
setContext(StoreContext) - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
 
setContext(StoreContext) - Method in class org.apache.openjpa.datacache.DataCacheStoreManager
 
setContext(QueryContext) - Method in class org.apache.openjpa.datacache.QueryCacheStoreQuery
 
setContext(StoreContext) - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
setContext(StoreContext) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
setContext(StoreContext) - Method in class org.apache.openjpa.jdbc.kernel.PessimisticLockManager
 
setContext(StoreContext) - Method in class org.apache.openjpa.kernel.AbstractLockManager
 
setContext(QueryContext) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery
 
setContext(StoreContext) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
setContext(StoreContext) - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
setContext(StoreContext) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Called automatically by the system to associate the fetch configuration with a context before use.
setContext(StoreContext) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
setContext(StoreContext) - Method in interface org.apache.openjpa.kernel.LockManager
Set the context this lock manager is associated with.
setContext(StoreContext) - Method in interface org.apache.openjpa.kernel.StoreManager
Set a reference to the corresponding context.
setContext(QueryContext) - Method in interface org.apache.openjpa.kernel.StoreQuery
Set the current query context.
setCopyObjectIds(boolean) - Method in class org.apache.openjpa.conf.Compatibility
Whether to copy identity objects before returning them to client code.
setCursorName(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setCursorName(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setCursorName(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
setCustomizer(ReverseCustomizer) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Set the customizer.
setCustomizerClass(String) - Method in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
Set a customizer class to use.
setCustomizerProperties(String) - Method in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
Set a properties file to pass to the customizer class.
setData(int, Object) - Method in class org.apache.openjpa.datacache.DataCachePCDataImpl
 
setData(int, Object) - Method in class org.apache.openjpa.kernel.PCDataImpl
 
setDataCache(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The DataCache to use for level-2 data store caching.
setDataCache(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setDataCacheManager(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The data cache manager manages this configuration's cache instances.
setDataCacheManager(DataCacheManager) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The data cache manager manages this configuration's cache instances.
setDataCacheManager(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setDataCacheManager(DataCacheManager) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setDataCacheName(String) - Method in class org.apache.openjpa.meta.ClassMetaData
Set the cache name for this class.
setDataCacheTimeout(int) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Default data cache timeout.
setDataCacheTimeout(Integer) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Wrapper for JCA usage of OpenJPAConfiguration.setDataCacheTimeout(int).
setDataCacheTimeout(int) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setDataCacheTimeout(Integer) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setDataCacheTimeout(int) - Method in class org.apache.openjpa.meta.ClassMetaData
The cache timeout for this class.
setDataStore(AbstractJDBCSavepointManager.ConnectionSavepoint) - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSavepointManager
Set the datastore savepoint.
setDataStore(AbstractJDBCSavepointManager.ConnectionSavepoint) - Method in class org.apache.openjpa.jdbc.kernel.JDBC3SavepointManager
 
setDataStoreIdColumnName(String) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default base name for datastore identity columns, or null to the mapping's built-in name.
setDataStoreObjectIdFieldUnwrapped(boolean) - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
 
setDataStoreSavepoint(Object) - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSavepointManager.ConnectionSavepoint
Set the implementation specific savepoint object
setDate(PreparedStatement, int, Date, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setDate(PreparedStatement, int, Date, Calendar, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setDate(Column, Date) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setDate(Column, Date, Calendar) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setDate(Column, Date) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setDate(Column, Date, Calendar) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setDate(int, Date) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setDate(int, Date, Calendar) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setDate(String, Date) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setDate(String, Date, Calendar) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setDate(int, Date) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setDate(int, Date, Calendar) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setDate(int) - Method in class org.apache.openjpa.util.ProxySQLDate
 
setDate(int) - Method in class org.apache.openjpa.util.ProxyTime
 
setDate(int) - Method in class org.apache.openjpa.util.ProxyTimestamp
 
setDate(int) - Method in class org.apache.openjpa.util.ProxyUtilDate
 
setDBDictionary(String) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The DBDictionary to use to define the RDBMS SQL information.
setDBDictionary(DBDictionary) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The DBDictionary to use.
setDBDictionary(String) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setDBDictionary(DBDictionary) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setDBSchemaGroup(SchemaGroup) - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Set the database schema.
setDecimalDigits(int) - Method in class org.apache.openjpa.jdbc.schema.Column
Set the number of decimal digits for the column.
setDeclaredCallbacks(int, LifecycleCallbacks[], int) - Method in class org.apache.openjpa.meta.LifecycleMetaData
Set the callbacks for the given event type.
setDeclaredIndex(int) - Method in class org.apache.openjpa.meta.FieldMetaData
The relative index of this persistent/transactional field.
setDeclaredInterfacePersistent(boolean) - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
 
setDeclaredType(Class) - Method in class org.apache.openjpa.meta.FieldMetaData
 
setDeclaredType(Class) - Method in interface org.apache.openjpa.meta.ValueMetaData
Set the declared class of the value.
setDeclaredType(Class) - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
setDeclaredTypeCode(int) - Method in class org.apache.openjpa.meta.FieldMetaData
 
setDeclaredTypeCode(int) - Method in interface org.apache.openjpa.meta.ValueMetaData
Set the type code for the value.
setDeclaredTypeCode(int) - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
setDeclaringType(Class) - Method in class org.apache.openjpa.meta.FieldMetaData
The declaring class.
setDefault(Object) - Method in class org.apache.openjpa.jdbc.schema.Column
Set the default value for the column.
setDefault(String) - Method in class org.apache.openjpa.lib.conf.Value
The default value for the propert as a string.
setDefaultAccessType(int) - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
The default access type for base classes with ACCESS_UNKNOWN.
setDefaultAccessType(String) - Method in class org.apache.openjpa.persistence.PersistenceMetaDataDefaults
Auto-configuration method for the default access type of base classes with ACCESS_UNKNOWN
setDefaultEntryDelimiter(char) - Method in class org.apache.openjpa.lib.util.FormatPreservingProperties
The character to use as a delimiter between property keys and values.
setDefaultFetchGroupExplicit(boolean) - Method in class org.apache.openjpa.meta.FieldMetaData
Whether the default fetch group setting is explicit.
setDefaultIdentityType(int) - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
The default identity type for unmapped classes without primary key fields.
setDefaultLevel(String) - Method in class org.apache.openjpa.lib.log.LogFactoryImpl
The string name of the default level for unconfigured log channels; used for automatic configuration.
setDefaultLevel(short) - Method in class org.apache.openjpa.lib.log.LogFactoryImpl
The default level for unconfigured log channels.
setDefaultMissingInfo(boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
setDefaultString(String) - Method in class org.apache.openjpa.jdbc.schema.Column
Set the default value for the column.
setDeferConstraints(boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Whether to defer constraints by default.
setDeferred(boolean) - Method in class org.apache.openjpa.jdbc.schema.Constraint
Make this constrain deferred.
setDefiningType(Class) - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping
The class that defines this query result, or null if none.
setDefiningType(Class) - Method in class org.apache.openjpa.meta.QueryMetaData
The class that defines this query, or null if none.
setDelayConstraintResolve(boolean) - Method in interface org.apache.openjpa.jdbc.schema.SchemaParser
Delay resolution of foreign key constraints until SchemaParser.resolveConstraints() is called.
setDelayConstraintResolve(boolean) - Method in class org.apache.openjpa.jdbc.schema.XMLSchemaParser
 
setDeleteAction(int) - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Set the delete action for the key.
setDependent(boolean) - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
Mark this row as dependent on some other row.
setDescribedType(Class) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
setDescribedType(Class) - Method in class org.apache.openjpa.meta.ClassMetaData
Set the class descibed by this metadata.
setDetachable(boolean) - Method in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
Set whether to make generated classes detachable.
setDetachable(boolean) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Whether to make generated classes detachable.
setDetachable(boolean) - Method in class org.apache.openjpa.meta.ClassMetaData
Whether instances are detachable.
setDetachedNew(boolean) - Method in interface org.apache.openjpa.kernel.Broker
Whether to treat relations to detached instances as new.
setDetachedNew(boolean) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
setDetachedNew(boolean) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
setDetachedState(String) - Method in class org.apache.openjpa.meta.ClassMetaData
The name of the detach state field, or null if none.
setDetachedStateField(boolean) - Method in class org.apache.openjpa.conf.DetachOptions
Whether to add a detached state field to enhanced classes.
setDetachedStateField(String) - Method in class org.apache.openjpa.conf.DetachOptions
For auto-configuration of the detached state field.
setDetachedStateManager(boolean) - Method in class org.apache.openjpa.conf.DetachOptions
Whether to use a detached state manager on types that allow it.
setDetachedStateTransient(boolean) - Method in class org.apache.openjpa.conf.DetachOptions
Whether to use transient detached state.
setDetachState(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Which field values to include when detaching.
setDetachState(DetachOptions) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Return the instance specified by the detach state plugin.
setDetachState(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setDetachState(DetachOptions) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setDetachState(int) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
setDetachState(int) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
setDetachState(int) - Method in interface org.apache.openjpa.kernel.StoreContext
Detach mode constant to determine which fields are part of the detached graph.
setDetachState(int) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
setDetachState(int) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Detach mode constant to determine which fields are part of the detached graph.
setDiagnosticContext(String) - Method in class org.apache.openjpa.lib.log.LogFactoryImpl
A string to prefix all log messages with.
setDirectory(String) - Method in class org.apache.openjpa.ant.ApplicationIdToolTask
Set the output directory we want the enhancer to write to.
setDirectory(String) - Method in class org.apache.openjpa.ant.PCEnhancerTask
Set the output directory we want the enhancer to write to.
setDirectory(File) - Method in class org.apache.openjpa.enhance.ApplicationIdTool
The directory to write source to.
setDirectory(File) - Method in class org.apache.openjpa.enhance.CodeGenerator
The directory to write source to.
setDirectory(File) - Method in class org.apache.openjpa.enhance.PCEnhancer
The base build directory to generate code to.
setDirectory(String) - Method in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
Set the output directory for the generated classes.
setDirectory(File) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
The file to output the generated code to, or null for the current directory.
setDiscriminator(Discriminator) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
 
setDiscriminator(Discriminator) - Method in interface org.apache.openjpa.jdbc.meta.DiscriminatorStrategy
Set the Discriminator that uses this strategy.
setDiscriminator(Discriminator) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractDiscriminatorStrategy
 
setDiscriminator(Discriminator) - Method in class org.apache.openjpa.jdbc.meta.strats.NoneDiscriminatorStrategy
 
setDiscriminatorColumnName(String) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default base name for discriminator columns, or null to the mapping's built-in name.
setDiscriminatorStrategy(String) - Method in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
Default discriminator strategy for base class mappings.
setDiscriminatorStrategy(String) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default discriminator strategy alias.
setDiscriminatorStrategy(String) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Default discriminator strategy for base class mappings.
setDistinct(boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
setDistinct(boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
setDistinct(boolean) - Method in interface org.apache.openjpa.jdbc.sql.SelectExecutor
Whether this is a SELECT DISTINCT / UNION ALL.
setDistinct(boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
setDocumentLocator(Locator) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
 
setDouble(int, double) - Method in interface org.apache.openjpa.enhance.DynamicStorage
Set the double at the given index.
setDouble(PreparedStatement, int, double, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setDouble(PreparedStatement, int, double, Column) - Method in class org.apache.openjpa.jdbc.sql.EmpressDictionary
 
setDouble(PreparedStatement, int, double, Column) - Method in class org.apache.openjpa.jdbc.sql.HSQLDictionary
 
setDouble(Column, double) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setDouble(Column, double) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setDouble(int, double) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setDouble(String, double) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setDouble(int, double) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setDoubleSpace(boolean) - Method in class org.apache.openjpa.lib.jdbc.SQLFormatter
If true, then output two lines after multi-line statements.
setDriverDataSource(String) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The DriverDataSource to use for creating a DataSource from a JDBC Driver.
setDriverDataSource(String) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setDropSequences(boolean) - Method in class org.apache.openjpa.jdbc.ant.MappingToolTask
Set whether the MappingTool should drop sequences.
setDropSequences(boolean) - Method in class org.apache.openjpa.jdbc.ant.SchemaToolTask
Set whether the SchemaTool should drop sequences.
setDropSequences(boolean) - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
If true, sequences that appear to be unused will be dropped.
setDropTables(boolean) - Method in class org.apache.openjpa.jdbc.ant.MappingToolTask
Set whether the MappingTool should drop tables.
setDropTables(boolean) - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
If true, tables that appear to be unused will be dropped.
setDropUnusedComponents(boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Whether schema components that are unused by any mapping will be dropped from this tool's SchemaGroup, and, depending on the schema action, from the database.
setDynamicDataStructs(boolean) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Set whether to generate dynamic data structures where possible for cache and runtime usage.
setDynamicDataStructs(Boolean) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Wrapper for JCA usage of OpenJPAConfiguration.setDynamicDataStructs(boolean).
setDynamicDataStructs(boolean) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setDynamicDataStructs(Boolean) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setEagerFetchMode(String) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Specifies the default eager fetch mode to use.
setEagerFetchMode(int) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Set the eager fetch mode as one of the following symbolic constants: EagerFetchModes.EAGER_NONE EagerFetchModes.EAGER_JOIN EagerFetchModes.EAGER_PARALLEL
setEagerFetchMode(String) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setEagerFetchMode(int) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setEagerFetchMode(int) - Method in class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
 
setEagerFetchMode(int) - Method in interface org.apache.openjpa.jdbc.kernel.JDBCFetchConfiguration
Set the eager fetch mode.
setEagerFetchMode(int) - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
setEagerFetchMode(int) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
The eager fetch mode, as one of the eager constants in JDBCFetchConfiguration.
setEagerFetchMode(int) - Method in interface org.apache.openjpa.persistence.jdbc.JDBCFetchPlan
Eager fetch mode in loading relations.
setEagerFetchMode(int) - Method in class org.apache.openjpa.persistence.jdbc.JDBCFetchPlanImpl
 
setEagerMap(Map) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
Raw eager information.
setElementAt(Object, int) - Method in class org.apache.openjpa.util.ProxyVector
 
setEmbedded(boolean) - Method in class org.apache.openjpa.meta.FieldMetaData
 
setEmbedded(boolean) - Method in interface org.apache.openjpa.meta.ValueMetaData
This attribute is a hint to the implementation to store this value in the same structure as the class, rather than as a separate datastore structure.
setEmbedded(boolean) - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
setEmbeddedOnly(boolean) - Method in class org.apache.openjpa.meta.ClassMetaData
Whether the type can only be used as an embedded object.
setEnforcePropertyRestrictions(boolean) - Method in class org.apache.openjpa.ant.PCEnhancerTask
Set whether to fail if the persistent type uses property access and bytecode analysis shows that it may be violating OpenJPA's property access restrictions.
setEnforcePropertyRestrictions(boolean) - Method in class org.apache.openjpa.enhance.PCEnhancer
Whether to fail if the persistent type uses property access and bytecode analysis shows that it may be violating OpenJPA's property access restrictions.
setEnvClassLoader(ClassLoader) - Method in class org.apache.openjpa.meta.ClassMetaData
The class environmental loader used when loading this metadata.
setEnvClassLoader(ClassLoader) - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Set the environmental class loader to pass on to parsed metadata instances.
setEnvClassLoader(ClassLoader) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Set the environmental class loader to pass on to parsed metadata instances.
setEscapeProcessing(boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setEscapeProcessing(boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setEscapeProcessing(boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
setEvictFromDataCache(boolean) - Method in interface org.apache.openjpa.kernel.Broker
Whether to also evict an object from the store cache when it is evicted through this broker.
setEvictFromDataCache(boolean) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
setEvictFromDataCache(boolean) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
setEvictFromStoreCache(boolean) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
setEvictFromStoreCache(boolean) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether to also evict an object from the store cache when it is evicted through this entity manager.
setEvictionSchedule(String) - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
setExceptionReconnectAttempts(int) - Method in class org.apache.openjpa.event.JMSRemoteCommitProvider
The number of times to attempt to reconnect after a JMS send exception is detected.
setExcludeUnlistedClasses(boolean) - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
setExplicit(boolean) - Method in class org.apache.openjpa.meta.FieldMetaData
Whether this field is explicitly declared in the metadata.
setExternalizer(String) - Method in class org.apache.openjpa.meta.FieldMetaData
The name of this field's externalizer, or null if none.
setExternalValues(String) - Method in class org.apache.openjpa.meta.FieldMetaData
Properties string mapping field values to external values.
setFactory(String) - Method in class org.apache.openjpa.meta.FieldMetaData
The name of this field's factory, or null if none.
setFailedObject(Object) - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
 
setFailedObject(Object) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the failed object to include in the optimistic lock exception that will be thrown if this update results in an update count of 0 when executed.
setFailedObject(Object) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
This implementation does not track failed objects.
setFailedObject(Object) - Method in exception org.apache.openjpa.util.OpenJPAException
The failed object.
setFailFast(boolean) - Method in class org.apache.openjpa.event.LifecycleEventManager
Whether to fail after first exception when firing events to listeners.
setFailFast(boolean) - Method in class org.apache.openjpa.lib.util.concurrent.AbstractConcurrentEventManager
Whether to fail after the first exception thrown by any listener.
setFatal(boolean) - Method in exception org.apache.openjpa.util.OpenJPAException
Whether this error is fatal.
setFetchBatchSize(int) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Set the size of the batch that will be pre-selected when accessing elements in a query or relationship.
setFetchBatchSize(Integer) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Wrapper for JCA usage of OpenJPAConfiguration.setFetchBatchSize(int).
setFetchBatchSize(int) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setFetchBatchSize(Integer) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setFetchBatchSize(int) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
setFetchBatchSize(int) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Set the fetch batch size for large result set support.
setFetchBatchSize(int) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
setFetchBatchSize(int) - Method in interface org.apache.openjpa.persistence.FetchPlan
Set the fetch batch size for large result set support.
setFetchBatchSize(int) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
setFetchDirection(String) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The JDBC fetch direction.
setFetchDirection(int) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Set the result set fetch direction constant.
setFetchDirection(String) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setFetchDirection(int) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setFetchDirection(int) - Method in class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
 
setFetchDirection(int) - Method in interface org.apache.openjpa.jdbc.kernel.JDBCFetchConfiguration
The fetch direction to use as a constant from ResultSet.
setFetchDirection(int) - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
setFetchDirection(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setFetchDirection(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setFetchDirection(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
setFetchDirection(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
setFetchDirection(int) - Method in interface org.apache.openjpa.persistence.jdbc.JDBCFetchPlan
Result set fetch direction.
setFetchDirection(int) - Method in class org.apache.openjpa.persistence.jdbc.JDBCFetchPlanImpl
 
setFetchGroups(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Comma-separated list of fetch group names that will be pre-set for all new FetchConfigurations.
setFetchGroups(String[]) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
List of fetch group names that will be pre-set for all new FetchConfigurations.
setFetchGroups(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setFetchGroups(String[]) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setFetchSize(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setFetchSize(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setFetchSize(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
setFetchSize(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
setField(int, Object) - Method in class org.apache.openjpa.xmlstore.ObjectData
Set the data for the field with the given index.
setFieldMapping(FieldMapping) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
setFieldMapping(FieldMapping) - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Set the class mapping using this strategy.
setFieldMapping(FieldMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
setFieldMapping(FieldMapping) - Method in class org.apache.openjpa.jdbc.meta.strats.NoneFieldStrategy
 
setFieldOverride(boolean) - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
Whether to use field-level override or class-level override.
setFieldStrategies(String) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Property string mapping field type names to value handler or field mapping class names.
setFieldStrategy(String, String) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Association of a field value type name with the handler or strategy class name.
setFile(String) - Method in class org.apache.openjpa.ant.MetaDataToolTask
Set the file to write the metadata to.
setFile(String) - Method in class org.apache.openjpa.jdbc.ant.MappingToolTask
Set the output file we want the MappingTool to write to.
setFile(String) - Method in class org.apache.openjpa.jdbc.ant.SchemaToolTask
Set the output file we want the SchemaTool to write to.
setFile(String) - Method in class org.apache.openjpa.jdbc.schema.FileSchemaFactory
Set the XML resource defining this schema.
setFile(String) - Method in class org.apache.openjpa.lib.log.LogFactoryImpl
The stream to write to.
setFile(File) - Method in class org.apache.openjpa.meta.MetaDataTool
The file to generate metadata to.
setFileName(String) - Method in class org.apache.openjpa.jdbc.schema.FileSchemaFactory
Deprecated. Use FileSchemaFactory.setFile(java.lang.String). Retained for backwards-compatible auto-configuration.
setFiles(Collection) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Set of Files of metadata files or directories supplied by user.
setFiles(String) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Set of semicolon-separated Files of metadata files or directories supplied by user via auto-configuration.
setFilterListeners(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
A comma-separted list of the plugin strings of the query FilterListeners to use.
setFilterListeners(FilterListener[]) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Set the query filter listeners.
setFilterListeners(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setFilterListeners(FilterListener[]) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setFirstDayOfWeek(int) - Method in class org.apache.openjpa.util.ProxyGregorianCalendar
 
setFirstResult(int) - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
 
setFirstResult(int) - Method in class org.apache.openjpa.persistence.QueryImpl
 
setFlag(int, boolean) - Method in class org.apache.openjpa.jdbc.schema.Column
Flags are used for bookkeeping information.
setFloat(int, float) - Method in interface org.apache.openjpa.enhance.DynamicStorage
Set the float at the given index.
setFloat(PreparedStatement, int, float, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setFloat(PreparedStatement, int, float, Column) - Method in class org.apache.openjpa.jdbc.sql.EmpressDictionary
 
setFloat(Column, float) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setFloat(Column, float) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setFloat(int, float) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setFloat(String, float) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setFloat(int, float) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setFlushBeforeQueries(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Sets whether or not OpenJPA should automatically flush modifications to the data store before executing queries.
setFlushBeforeQueries(int) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Set to one of QueryFlushModes.FLUSH_TRUE, QueryFlushModes.FLUSH_FALSE, or QueryFlushModes.FLUSH_WITH_CONNECTION.
setFlushBeforeQueries(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setFlushBeforeQueries(int) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setFlushBeforeQueries(int) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
setFlushBeforeQueries(int) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
The query automatic flush configuration.
setFlushBeforeQueries(int) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
setFlushMode(FlushModeType) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
setFlushMode(FlushModeType) - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
 
setFlushMode(FlushModeType) - Method in class org.apache.openjpa.persistence.QueryImpl
 
setForeignKey(ForeignKey) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
setForeignKey(Row, OpenJPAStateManager) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
setForeignKey(ForeignKey) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Raw foreign key information.
setForeignKey(ForeignKey) - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
If this value joins to another record, the foreign key.
setForeignKey(Row, OpenJPAStateManager) - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
Sets this value's foreign key to the given related object.
setForeignKey(ForeignKey) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
setForeignKey(Row, OpenJPAStateManager) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
setForeignKey(ForeignKey, OpenJPAStateManager) - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
 
setForeignKey(ForeignKey, ColumnIO, OpenJPAStateManager) - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
 
setForeignKey(ForeignKey, OpenJPAStateManager) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given foreign key to the given object.
setForeignKey(ForeignKey, ColumnIO, OpenJPAStateManager) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given foreign key to the given object.
setForeignKey(ForeignKey, OpenJPAStateManager) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setForeignKey(ForeignKey, ColumnIO, OpenJPAStateManager) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setForeignKey(ForeignKey, OpenJPAStateManager) - Method in class org.apache.openjpa.jdbc.sql.SecondaryRow
 
setForeignKey(ForeignKey, ColumnIO, OpenJPAStateManager) - Method in class org.apache.openjpa.jdbc.sql.SecondaryRow
 
setForeignKeyDeleteAction(int) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default foreign key action for relation keys.
setForeignKeyDeleteAction(String) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default foreign key action name for relation keys.
setForeignKeys(boolean) - Method in class org.apache.openjpa.jdbc.ant.MappingToolTask
Set whether to generate foreign key information.
setForeignKeys(boolean) - Method in class org.apache.openjpa.jdbc.ant.SchemaToolTask
Set whether to generate foreign key information.
setForeignKeys(boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Whether foreign keys on existing tables should be manipulated.
setForeignKeys(boolean) - Method in class org.apache.openjpa.jdbc.schema.LazySchemaFactory
 
setForeignKeys(boolean) - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Set whether foreign keys should be generated.
setForeignKeys(boolean) - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Whether foreign keys on existing tables should be manipulated.
setFormat(String) - Method in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
Deprecated. Retained for backwards-compatibility for auto-configuration.
setFrom(Query) - Method in class org.apache.openjpa.meta.QueryMetaData
Initialize this instance from the values held in the specified Query.
setFromCmdLine(String[]) - Method in class org.apache.openjpa.lib.util.Options
Parses the given argument list into flag/value pairs, which are stored as properties.
setFromSelect(Select) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
setFromSelect(Select) - Method in interface org.apache.openjpa.jdbc.sql.Select
Another select instance that creates a temporary table from which this select pulls data.
setFromSelect(Select) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
setHaltOnError(boolean) - Method in class org.apache.openjpa.lib.ant.AbstractTask
Set whether we want the task to ignore all errors.
setHandler(ValueHandler) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
setHandler(ValueHandler) - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
The handler used for this value, or null if none.
setHandler(ValueHandler) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
setHierarchyStrategy(String) - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
The default strategy for subclasses in this hierarchy.
setHint(String, Object) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
setHint(String, Object) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Sets an arbitrary query hint that may be utilized during execution.
setHint(String, Object) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
setHint(String, Object) - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
 
setHint(String, Object) - Method in class org.apache.openjpa.persistence.QueryImpl
 
setHoldability(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
setHours(int) - Method in class org.apache.openjpa.util.ProxySQLDate
 
setHours(int) - Method in class org.apache.openjpa.util.ProxyTime
 
setHours(int) - Method in class org.apache.openjpa.util.ProxyTimestamp
 
setHours(int) - Method in class org.apache.openjpa.util.ProxyUtilDate
 
setId(Object) - Method in interface org.apache.openjpa.enhance.PCDataGenerator.DynamicPCData
 
setIdentityClassSuffix(String) - Method in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
The suffix to use to create the identity class name for a class, or for inner classes, the name of the inner class.
setIdentityClassSuffix(String) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Suffix used to create application identity class name from a class name, or in the case of inner identity classes, the inner class name.
setIdentitySequenceName(String) - Method in class org.apache.openjpa.meta.ClassMetaData
The datastore identity sequence name, or null for none.
setIdentityStrategy(int) - Method in class org.apache.openjpa.meta.ClassMetaData
The strategy to use for datastore identity generation.
setIdentityType(int) - Method in class org.apache.openjpa.meta.ClassMetaData
The type of identity being used.
setIgnoreChanges(boolean) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Whether changes in the current transaction are taken into account when executing queries and iterating extents.
setIgnoreChanges(Boolean) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Wrapper for JCA usage of OpenJPAConfiguration.setIgnoreChanges(boolean).
setIgnoreChanges(boolean) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setIgnoreChanges(Boolean) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setIgnoreChanges(boolean) - Method in interface org.apache.openjpa.kernel.Broker
Whether to take into account changes in the transaction when executing a query or iterating an extent.
setIgnoreChanges(boolean) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
setIgnoreChanges(boolean) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
setIgnoreChanges(boolean) - Method in class org.apache.openjpa.kernel.DelegatingExtent
 
setIgnoreChanges(boolean) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
setIgnoreChanges(boolean) - Method in interface org.apache.openjpa.kernel.Extent
Whether this extent will ignore changes made in the current transaction.
setIgnoreChanges(boolean) - Method in class org.apache.openjpa.kernel.ExtentImpl
 
setIgnoreChanges(boolean) - Method in interface org.apache.openjpa.kernel.Query
Whether to ignore changes in the current transaction.
setIgnoreChanges(boolean) - Method in class org.apache.openjpa.kernel.QueryImpl
 
setIgnoreChanges(boolean) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
setIgnoreChanges(boolean) - Method in interface org.apache.openjpa.persistence.Extent
Whether the extent sees inserts and deletes in the current transaction.
setIgnoreChanges(boolean) - Method in class org.apache.openjpa.persistence.ExtentImpl
 
setIgnoreChanges(boolean) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether to take into account changes in the transaction when executing a query or iterating an extent.
setIgnoreChanges(boolean) - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Whether to ignore changes in the current transaction.
setIgnoreChanges(boolean) - Method in class org.apache.openjpa.persistence.QueryImpl
 
setIgnoreErrors(boolean) - Method in class org.apache.openjpa.ant.ApplicationIdToolTask
Set whether to ignore errors.
setIgnoreErrors(boolean) - Method in class org.apache.openjpa.enhance.ApplicationIdTool
Set to false if this tool should throw an exception on an attempt to generate an id class for a type that does not use application identity.
setIgnoreErrors(boolean) - Method in class org.apache.openjpa.jdbc.ant.MappingToolTask
Set whether we want the MappingTool to ignore SQL errors.
setIgnoreErrors(boolean) - Method in class org.apache.openjpa.jdbc.ant.SchemaToolTask
Set whether we want the SchemaTool to ignore SQL errors.
setIgnoreErrors(boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Whether and SQL errors should cause a failure or just issue a warning.
setIgnoreErrors(boolean) - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
If true, SQLExceptions thrown during schema manipulation will be printed but ignored.
setIgnoreNonPersistent(boolean) - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
 
setIgnoreNonPersistent(boolean) - Method in interface org.apache.openjpa.meta.MetaDataDefaults
Whether to ignore members which are not persistent by default during metadata population.
setIgnoreNonPersistent(boolean) - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
setIgnoreSuperclassCallbacks(int) - Method in class org.apache.openjpa.meta.LifecycleMetaData
Whether to exclude superclass callbacks from events.
setIgnoreSystemListeners(boolean) - Method in class org.apache.openjpa.meta.LifecycleMetaData
Whether to exclude system listeners from events.
setIgnoreUnmapped(boolean) - Method in class org.apache.openjpa.jdbc.kernel.ClassTableJDBCSeq
Whether unmapped classes should be ignored as possible primary key values in the table.
setIgnoreVirtual(boolean) - Method in class org.apache.openjpa.jdbc.kernel.ClassTableJDBCSeq
Deprecated. Use ClassTableJDBCSeq.setIgnoreUnmapped(boolean). Retained for backwards-compatibility for auto-configuration.
setImplData(Object) - Method in class org.apache.openjpa.datacache.DataCachePCDataImpl
 
setImplData(int, Object) - Method in class org.apache.openjpa.datacache.DataCachePCDataImpl
 
setImplData(Object, boolean) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
setImplData(int, Object) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
setImplData(Object, boolean) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
setImplData(int, Object) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
setImplData(Object, boolean) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
setImplData(int, Object) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
setImplData(Object, boolean) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
An object that concrete back ends can associate with each instance.
setImplData(int, Object) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Field-level impl data.
setImplData(Object) - Method in interface org.apache.openjpa.kernel.PCData
Sets the stored instance-level impl data.
setImplData(Object) - Method in class org.apache.openjpa.kernel.PCDataImpl
 
setImplData(int, Object) - Method in class org.apache.openjpa.kernel.PCDataImpl
 
setImplData(Object, boolean) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
setImplData(int, Object) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
setImplicitBehavior(OpCallbacks, RuntimeExceptionTranslator) - Method in interface org.apache.openjpa.kernel.Broker
Set the broker's behavior for implicit actions such as flushing, automatic detachment, and exceptions thrown by managed instances outside a broker operation.
setImplicitBehavior(OpCallbacks, RuntimeExceptionTranslator) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
setImplicitBehavior(OpCallbacks, RuntimeExceptionTranslator) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
setImplicitContainsTypes(Value, Value, int) - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
Set the implicit types of the given values based on the fact that the first is supposed to contain the second.
setImplicitType(Class) - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
 
setImplicitType(Value, Class) - Static method in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
Set the implicit type of the given value to the given class.
setImplicitType(Class) - Method in interface org.apache.openjpa.kernel.exps.Value
Set the implicit type of the value, based on how it is used in the filter.
setImplicitTypes(Value, Value, Class) - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
Set the implicit types of the given values based on the fact that they're used together, and based on the operator type.
setIncrement(int) - Method in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
 
setIncrement(int) - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
Deprecated. Use TableJDBCSeq.setAllocate(int). Retained for backwards compatibility of auto-configuration.
setIncrement(int) - Method in class org.apache.openjpa.jdbc.schema.Sequence
The sequence's increment.
setIncrement(int) - Method in class org.apache.openjpa.kernel.TimeSeededSeq
 
setIncrement(int) - Method in class org.apache.openjpa.meta.SequenceMetaData
Sequence increment, or -1 for default.
setInDefaultFetchGroup(boolean) - Method in class org.apache.openjpa.meta.FieldMetaData
Whether this field is in the default fetch group.
setIndex(Index) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
Index on the Discriminator columns, or null if none.
setIndex(Index) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Raw index.
setIndex(Index) - Method in class org.apache.openjpa.jdbc.meta.Version
Index on the version columns, or null if none.
setIndex(int) - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
The index of this row in ordered row list.
setIndex(int) - Method in interface org.apache.openjpa.kernel.exps.Parameter
Set the index of this parameter.
setIndex(int) - Method in class org.apache.openjpa.meta.FieldMetaData
The absolute index of this persistent/transactional field.
setIndexDiscriminator(boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Whether to index discriminator columns by default.
setIndexes(boolean) - Method in class org.apache.openjpa.jdbc.ant.MappingToolTask
Set whether to generate index information.
setIndexes(boolean) - Method in class org.apache.openjpa.jdbc.ant.SchemaToolTask
Set whether to generate index information.
setIndexes(boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Whether indexes on existing tables should be manipulated.
setIndexes(boolean) - Method in class org.apache.openjpa.jdbc.schema.LazySchemaFactory
 
setIndexes(boolean) - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Set whether indexes should be generated.
setIndexes(boolean) - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Whether indexes on existing tables should be manipulated.
setIndexLogicalForeignKeys(boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Whether to index logical foreign keys by default.
setIndexOf(int) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
setIndexVersion(boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Whether to index version columns by default.
setInFetchGroup(String, boolean) - Method in class org.apache.openjpa.meta.FieldMetaData
Set whether this field is in the given fetch group.
setInitializer(Object) - Method in class org.apache.openjpa.meta.FieldMetaData
The initializer used by the field, or null if none.
setInitialValue(int) - Method in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
 
setInitialValue(int) - Method in class org.apache.openjpa.jdbc.meta.strats.NumberVersionStrategy
Set the initial value for version column.
setInitialValue(int) - Method in class org.apache.openjpa.jdbc.schema.Sequence
The sequence's initial value.
setInitialValue(int) - Method in class org.apache.openjpa.meta.SequenceMetaData
Initial sequence value, or -1 for default.
setInnerIdentityClasses(boolean) - Method in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
Whether or not to generate application identity classes as inner classes.
setInnerIdentityClasses(boolean) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Whether or not to generate inner classes when creating application identity classes.
setInsertable(int, boolean) - Method in class org.apache.openjpa.jdbc.schema.ColumnIO
Whether the column at the given index is insertable in this context.
setInsertTimestamp(boolean) - Method in class org.apache.openjpa.lib.util.FormatPreservingProperties
If set to true, this properties object will add a timestamp to the beginning of the file, just after the header (if any) is printed.
setInstantiatingGetter(String) - Method in class org.apache.openjpa.lib.conf.Value
The name of the getter method for the instantiated value of this property(as opposed to the string value).
setInt(int, int) - Method in interface org.apache.openjpa.enhance.DynamicStorage
Set the int at the given index.
setInt(PreparedStatement, int, int, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setInt(Column, int) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setInt(Column, int) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setInt(int, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setInt(String, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setInt(int, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setIntegrityViolation(int) - Method in exception org.apache.openjpa.util.ReferentialIntegrityException
The type of integrity violation that occurred.
setInterfaceImpl(Class) - Method in class org.apache.openjpa.meta.ClassMetaData
Set the managed interface implementor class.
setInterfacePropertyAlias(Class, String, String) - Method in class org.apache.openjpa.meta.ClassMetaData
Alias properties from the given interface during queries to the local field.
setIntermediate(int, Object) - Method in class org.apache.openjpa.datacache.DataCachePCDataImpl
 
setIntermediate(int, Object) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
setIntermediate(int, Object) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
setIntermediate(int, Object) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
setIntermediate(int, Object) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Use intermediate field data to store intermediate information that might be available before the field is fully loaded.
setIntermediate(int, Object) - Method in class org.apache.openjpa.kernel.PCDataImpl
 
setIntermediate(int, Object) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
setInternalObject(Object) - Method in class org.apache.openjpa.lib.conf.BooleanValue
 
setInternalObject(Object) - Method in class org.apache.openjpa.lib.conf.DoubleValue
 
setInternalObject(Object) - Method in class org.apache.openjpa.lib.conf.FileValue
 
setInternalObject(Object) - Method in class org.apache.openjpa.lib.conf.IntValue
 
setInternalObject(Object) - Method in class org.apache.openjpa.lib.conf.ObjectValue
 
setInternalObject(Object) - Method in class org.apache.openjpa.lib.conf.StringListValue
 
setInternalObject(Object) - Method in class org.apache.openjpa.lib.conf.StringValue
 
setInternalObject(Object) - Method in class org.apache.openjpa.lib.conf.Value
Set this value from an object.
setInternalString(String) - Method in class org.apache.openjpa.lib.conf.BooleanValue
 
setInternalString(String) - Method in class org.apache.openjpa.lib.conf.DoubleValue
 
setInternalString(String) - Method in class org.apache.openjpa.lib.conf.FileValue
 
setInternalString(String) - Method in class org.apache.openjpa.lib.conf.IntValue
 
setInternalString(String) - Method in class org.apache.openjpa.lib.conf.ObjectValue
 
setInternalString(String) - Method in class org.apache.openjpa.lib.conf.PluginListValue
 
setInternalString(String) - Method in class org.apache.openjpa.lib.conf.PluginValue
 
setInternalString(String) - Method in class org.apache.openjpa.lib.conf.StringListValue
 
setInternalString(String) - Method in class org.apache.openjpa.lib.conf.StringValue
 
setInternalString(String) - Method in class org.apache.openjpa.lib.conf.Value
Set this value from the given string.
setInterval(int) - Method in class org.apache.openjpa.datacache.DataCacheScheduler
The interval time in minutes between cache checks.
setInto(Options) - Method in class org.apache.openjpa.event.JMSRemoteCommitProvider
Set a map of properties to pass to the InitialContext constructor for JNDI lookups.
setInto(Configuration) - Method in interface org.apache.openjpa.lib.conf.ConfigurationProvider
Set loaded information into the given configuration.
setInto(Options) - Method in interface org.apache.openjpa.lib.conf.GenericConfigurable
Perform any generic configuration based on the data in opts.
setInto(Configuration) - Method in class org.apache.openjpa.lib.conf.MapConfigurationProvider
 
setInto(Configuration, Log) - Method in class org.apache.openjpa.lib.conf.MapConfigurationProvider
Set properties into configuration.
setInto(Options) - Method in class org.apache.openjpa.lib.log.LogFactoryImpl
 
setInto(Object) - Method in class org.apache.openjpa.lib.util.Options
This method uses reflection to set all the properties in the given object that are named by the keys in this map.
setInto(Query) - Method in class org.apache.openjpa.meta.QueryMetaData
Set query template information into the given concrete query instance.
setInto(Options) - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
 
setInto(Configuration) - Method in class org.apache.openjpa.persistence.PersistenceProductDerivation.ConfigurationProviderImpl
 
setInverse(String) - Method in class org.apache.openjpa.meta.FieldMetaData
Logical inverse field.
setInverseManager(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The plugin to use for managing inverse relations.
setInverseManager(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setInverseRelations(boolean) - Method in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
Set whether to generate inverse 1-many/1-1 relations for all many-1/1-1 relations.
setInverseRelations(boolean) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Whether to generate inverse 1-many/1-1 relations for all many-1/1-1 relations.
setIsolate(boolean) - Method in class org.apache.openjpa.lib.ant.AbstractTask
Whether we want the ClassLoader to be isolated from all other ClassLoaders
setJavaType(int) - Method in class org.apache.openjpa.jdbc.schema.Column
The Java type the data in this column is treated as, from JavaTypes or JavaSQLTypes.
setJDBCListeners(String) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
A comma-separated list of the JDBCListener plugins for listening to JDBCEvents.
setJDBCListeners(JDBCListener[]) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The JDBCListeners to use.
setJDBCListeners(String) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setJDBCListeners(JDBCListener[]) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setJDBCLog(Log) - Method in class org.apache.openjpa.lib.jdbc.DataSourceLogs
The log to write JDBC messages to.
setJoinable(Column, Joinable) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Add the given column-to-joinable mapping.
setJoinColumnIO(ColumnIO) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
I/O information on the join columns.
setJoinDirection(int) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
setJoinDirection(int) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Direction of the join that the columns of this mapping info form.
setJoinDirection(int) - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
The join direction.
setJoinDirection(int) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
setJoinedSubclass(boolean) - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
Whether there is a join to the superclass table.
setJoinForeignKey(ForeignKey) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Foreign key linking the primary key columns to the superclass table, or null if none.
setJoinForeignKey(ForeignKey) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Foreign key linking the field table to the class' primary table.
setJoinForeignKeyDeleteAction(int) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default foreign key action for join keys.
setJoinForeignKeyDeleteAction(String) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default foreign key action name for join keys.
setJoinIndex(Index) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Index on join foreign key columns.
setJoinOuter(boolean) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Whether to use an outer join from the class' primary table.
setJoinOuter(boolean) - Method in class org.apache.openjpa.jdbc.meta.FieldMappingInfo
Whether the field's table is joined to the class table through an outer join.
setJoins(Column[], Column[]) - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Set the foreign key's joins.
setJoinSyntax(int) - Method in class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
 
setJoinSyntax(int) - Method in interface org.apache.openjpa.jdbc.kernel.JDBCFetchConfiguration
The join syntax to use.
setJoinSyntax(int) - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
setJoinSyntax(String) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the name of the join syntax to use: sql92, traditional, database
setJoinSyntax(int) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
setJoinSyntax(int) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
setJoinSyntax(int) - Method in interface org.apache.openjpa.jdbc.sql.SelectExecutor
The join syntax for this select, as one of the syntax constants from JoinSyntaxes.
setJoinSyntax(int) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
setJoinSyntax(int) - Method in interface org.apache.openjpa.persistence.jdbc.JDBCFetchPlan
SQL join syntax.
setJoinSyntax(int) - Method in class org.apache.openjpa.persistence.jdbc.JDBCFetchPlanImpl
 
setJoinUnique(Unique) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Unique constraint on join foreign key columns.
setJtaDataSource(DataSource) - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
setJtaDataSourceName(String) - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
setKeySequence(int) - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
The sequence of this join in the foreign key.
setLanguage(String) - Method in class org.apache.openjpa.meta.QueryMetaData
Set the language for this query.
setLargeTransaction(boolean) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
setLargeTransaction(boolean) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
setLargeTransaction(boolean) - Method in interface org.apache.openjpa.kernel.StoreContext
If a large number of objects will be created, modified, or deleted during this transaction setting this option to true will reduce memory usage if you perform periodic flushes.
setLargeTransaction(boolean) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
setLargeTransaction(boolean) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
If a large number of objects will be created, modified, or deleted during this transaction setting this option to true will reduce memory usage if you perform periodic flushes.
setLenient(boolean) - Method in class org.apache.openjpa.util.ProxyGregorianCalendar
 
setLevel(short) - Method in class org.apache.openjpa.event.LogOrphanedKeyAction
The level to log at.
setLevel(String) - Method in class org.apache.openjpa.event.LogOrphanedKeyAction
The level to log at.
setLevel(short) - Method in class org.apache.openjpa.lib.log.LogFactoryImpl.LogImpl
 
setLexicalHandler(LexicalHandler) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
The lexical handler that should be registered with the SAX parser used by this class.
setLifecycleListenerCallbackMode(int) - Method in interface org.apache.openjpa.kernel.Broker
The callback mode for handling exceptions from lifecycle event listeners.
setLifecycleListenerCallbackMode(int) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
setLifecycleListenerCallbackMode(int) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
setLifecycleListenerCallbackMode(int) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
setLifecycleListenerCallbackMode(int) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
The CallbackModes flags for handling lifecycle listener exceptions.
setLineLength(int) - Method in class org.apache.openjpa.lib.jdbc.SQLFormatter
 
setLinesBetweenSections(int) - Method in class org.apache.openjpa.lib.util.CodeFormat
The number of empty lines between sections.
setListener(ValueListener) - Method in class org.apache.openjpa.lib.conf.Value
Listener for value changes.
setListingIndex(int) - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping
Relative order of result mapping in metadata.
setListingIndex(int) - Method in class org.apache.openjpa.meta.ClassMetaData
The index in which this field was listed in the metadata.
setListingIndex(int) - Method in class org.apache.openjpa.meta.FieldMetaData
The index in which this field was listed in the metadata.
setListingIndex(int) - Method in class org.apache.openjpa.meta.NonPersistentMetaData
The index in which this field was listed in the metadata.
setLoaded(int, boolean) - Method in class org.apache.openjpa.datacache.DataCachePCDataImpl
 
setLoaded(int, boolean) - Method in class org.apache.openjpa.kernel.PCDataImpl
 
setLoaded(Object[], BitSet) - Static method in class org.apache.openjpa.util.ArrayStateImage
Set the loaded mask into a state image.
setLoadFetchGroup(String) - Method in class org.apache.openjpa.meta.FieldMetaData
The fetch group that is to be loaded when this receiver is loaded, or null if none set.
setLoadKey(String) - Method in class org.apache.openjpa.lib.conf.Value
The key under which this value was loaded, or null.
setLoadObjectIds() - Method in interface org.apache.openjpa.enhance.ApplicationIdTool.ObjectIdLoader
Turn on the loading of all identity classes, even if they don't exist.
setLob(boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
setLob(boolean) - Method in interface org.apache.openjpa.jdbc.sql.Select
Set to true for selects that include LOB columns.
setLob(boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
setLocale(PreparedStatement, int, Locale, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setLocale(Column, Locale) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setLocale(Column, Locale) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setLocation(Location) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
The XML document location.
setLocator(Locator) - Method in class org.apache.openjpa.lib.xml.Location
 
setLock(Object) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
setLock(Object) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
setLock(Object) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
setLock(Object) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
The lock object set for this instance.
setLock(Object) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
setLocking(boolean) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
setLockLevel(OpenJPAStateManager, int) - Method in class org.apache.openjpa.kernel.VersionLockManager
Sets the given instance's lock level to the given number.
setLockManager(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The plugin to use for datastore lock management.
setLockManager(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setLockTimeout(int) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The time to wait for an object lock in milliseconds, or -1 for no timeout.
setLockTimeout(Integer) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Wrapper for JCA usage of OpenJPAConfiguration.setLockTimeout(int).
setLockTimeout(int) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setLockTimeout(Integer) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setLockTimeout(int) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
setLockTimeout(int) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
The number of milliseconds to wait for an object lock, or -1 for no limit.
setLockTimeout(int) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
setLockTimeout(int) - Method in interface org.apache.openjpa.persistence.FetchPlan
The number of milliseconds to wait for an object lock, or -1 for no limit.
setLockTimeout(int) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
setLog(String) - Method in interface org.apache.openjpa.lib.conf.Configuration
Log plugin setting.
setLog(String) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
setLog(Log) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
The log to write to.
setLog(Log) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
The log to write to.
setLogFactory(LogFactory) - Method in interface org.apache.openjpa.lib.conf.Configuration
The log factory.
setLogFactory(LogFactory) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
setLogical(boolean) - Method in class org.apache.openjpa.jdbc.schema.PrimaryKey
 
setLoginTimeout(int) - Method in class org.apache.openjpa.jdbc.schema.SimpleDriverDataSource
 
setLoginTimeout(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDataSource
 
setLogWriter(PrintWriter) - Method in class org.apache.openjpa.jdbc.schema.SimpleDriverDataSource
 
setLogWriter(PrintWriter) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDataSource
 
setLong(int, long) - Method in interface org.apache.openjpa.enhance.DynamicStorage
Set the long at the given index.
setLong(PreparedStatement, int, long, Column) - Method in class org.apache.openjpa.jdbc.sql.AccessDictionary
 
setLong(PreparedStatement, int, long, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setLong(Column, long) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setLong(Column, long) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setLong(int, long) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setLong(String, long) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setLong(int, long) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setLRS(boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
setLRS(boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
setLRS(boolean) - Method in interface org.apache.openjpa.jdbc.sql.SelectExecutor
Whether the result of this select should be treated as a large result set.
setLRS(boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
setLRS(boolean) - Method in class org.apache.openjpa.meta.FieldMetaData
Whether this field is backed by a large result set.
setLRSSize(String) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
How to obtain the size of large result sets.
setLRSSize(int) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Set the fetch configuration large result set size constant.
setLRSSize(String) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setLRSSize(int) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setLRSSize(int) - Method in class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
 
setLRSSize(int) - Method in interface org.apache.openjpa.jdbc.kernel.JDBCFetchConfiguration
The large result set size mode to use.
setLRSSize(int) - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
setLRSSize(int) - Method in interface org.apache.openjpa.persistence.jdbc.JDBCFetchPlan
How to determine the size of a large result set.
setLRSSize(int) - Method in class org.apache.openjpa.persistence.jdbc.JDBCFetchPlanImpl
 
setManagedInstanceType(Class) - Method in class org.apache.openjpa.util.OpenJPAId
Set the exact type of the described instance once it is known.
setManagedInterface(boolean) - Method in class org.apache.openjpa.meta.ClassMetaData
Whether the type is a managed interface
setManagedRuntime(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The plugin string for the ManagedRuntime to use for managed environments.
setManagedRuntime(ManagedRuntime) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The plugin to use for integrating with a managed runtime.
setManagedRuntime(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setManagedRuntime(ManagedRuntime) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setManageLRS(boolean) - Method in class org.apache.openjpa.kernel.InverseManager
Set whether to false LRS relations.
setManagement(int) - Method in class org.apache.openjpa.meta.FieldMetaData
Return the management level for the field.
setMappedBy(String) - Method in class org.apache.openjpa.meta.FieldMetaData
The field that this field shares a mapping with.
setMappedMetaDataFactoryDefault(String, String) - Method in class org.apache.openjpa.jdbc.conf.MappingFactoryValue
If the Mapping property is set, we check these defaults before checking metadata factory defaults.
setMapping(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The name mapping to use for this data store.
setMapping(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setMappingDefaults(String) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
A plugin string describing the MappingDefaults to use.
setMappingDefaults(MappingDefaults) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The MappingDefaults to use with a repository.
setMappingDefaults(String) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setMappingDefaults(MappingDefaults) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setMappingDefaults(MappingDefaults) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Mapping default.
setMappingFactory(String) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
A plugin string describing the MetaDataFactory to use for loading and storing object-relational mapping data.
setMappingFactory(String) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setMappingFile(File) - Method in class org.apache.openjpa.jdbc.meta.SequenceMapping
Allow sequence to have a mapping file separate from its metadata source file.
setMappingOverride(boolean) - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Whether to allow later parses of mapping information to override earlier information for the same class.
setMappingOverride(boolean) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Whether to allow later parses of mapping information to override earlier information for the same class.
setMappingWriter(Writer) - Method in class org.apache.openjpa.jdbc.meta.MappingTool
The stream to export the planned mappings to as an XML document.
setMaxActive(int) - Method in class org.apache.openjpa.event.TCPRemoteCommitProvider
The maximum number of sockets that this provider can simetaneously open to each peer in the cluster.
setMaxFetchDepth(int) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The maximum relation depth to traverse when eager fetching.
setMaxFetchDepth(Integer) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Wrapper for JCA usage of OpenJPAConfiguration.setMaxFetchDepth(int).
setMaxFetchDepth(int) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setMaxFetchDepth(Integer) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setMaxFetchDepth(int) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
setMaxFetchDepth(int) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Set the maximum depth of the fetched instance graph.
setMaxFetchDepth(int) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
setMaxFetchDepth(int) - Method in interface org.apache.openjpa.persistence.FetchPlan
The maximum fetch depth when loading an object.
setMaxFetchDepth(int) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
setMaxFieldSize(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setMaxFieldSize(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setMaxFieldSize(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
setMaxIdle(int) - Method in class org.apache.openjpa.event.TCPRemoteCommitProvider
The number of idle sockets that this provider can keep open to each peer in the cluster.
setMaxResults(int) - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
 
setMaxResults(int) - Method in class org.apache.openjpa.persistence.QueryImpl
 
setMaxRows(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setMaxRows(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setMaxRows(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
setMaxSize(int) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
 
setMaxSize(int) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
 
setMaxSize(int) - Method in class org.apache.openjpa.lib.util.LRUMap
 
setMaxSize(int) - Method in class org.apache.openjpa.lib.util.ReferenceHashMap
 
setMaxSize(int) - Method in interface org.apache.openjpa.lib.util.SizedMap
The maximum number of entries, or Integer.MAX_VALUE for no limit.
setMeta(boolean) - Method in class org.apache.openjpa.jdbc.ant.MappingToolTask
Set whether this action applies to metadata as well as mappings.
setMetadata(ReverseMappingToolTask.Level) - Method in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
Set the level of the generated metadata.
setMetaData(ClassMetaData) - Method in class org.apache.openjpa.jdbc.kernel.exps.Args
 
setMetaData(ClassMetaData) - Method in class org.apache.openjpa.kernel.exps.Val
 
setMetaData(ClassMetaData) - Method in interface org.apache.openjpa.kernel.exps.Value
Associate a persistent type with this value.
setMetaDataFactory(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
A plugin string describing the MetaDataFactory to use.
setMetaDataFactory(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setMetaDataFactory(MetaDataFactory) - Method in class org.apache.openjpa.meta.MetaDataRepository
The I/O used to load metadata.
setMetaDataFactoryDefault(String, String) - Method in class org.apache.openjpa.jdbc.conf.MappingFactoryValue
Default setting for a given MetaDataFactory alias setting.
setMetaDataFile(File) - Method in class org.apache.openjpa.jdbc.meta.MappingTool
If adding metadata, the metadata file to add to.
setMetaDataRepository(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
A plugin string describing the MetaDataRepository to use.
setMetaDataRepository(MetaDataRepository) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The metadata repository of managed class information.
setMetaDataRepository(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setMetaDataRepository(MetaDataRepository) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setMetaDataStructure(String, String, String[], String) - Method in class org.apache.openjpa.lib.meta.ClassArgParser
Set the the relevant metadata file structure so that metadata files containing class names can be parsed.
setMinimalDaysInFirstWeek(int) - Method in class org.apache.openjpa.util.ProxyGregorianCalendar
 
setMinutes(int) - Method in class org.apache.openjpa.util.ProxySQLDate
 
setMinutes(int) - Method in class org.apache.openjpa.util.ProxyTime
 
setMinutes(int) - Method in class org.apache.openjpa.util.ProxyTimestamp
 
setMinutes(int) - Method in class org.apache.openjpa.util.ProxyUtilDate
 
setMode(int) - Method in interface org.apache.openjpa.meta.AbstractCFMetaDataFactory.Parser
The parse mode according to the expected document type.
setMode(int) - Method in interface org.apache.openjpa.meta.AbstractCFMetaDataFactory.Serializer
The serialization mode according to the expected document type.
setMode(int, boolean) - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
The parse mode.
setMode(int) - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
The parse mode.
setMode(int, boolean) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
The parse mode according to the expected document type.
setMode(int) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
The parse mode according to the expected document type.
setMode(int) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
The serialization mode according to the expected document type.
setMode(int, boolean) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
The serialization mode according to the expected document type.
setMonth(int) - Method in class org.apache.openjpa.util.ProxySQLDate
 
setMonth(int) - Method in class org.apache.openjpa.util.ProxyTime
 
setMonth(int) - Method in class org.apache.openjpa.util.ProxyTimestamp
 
setMonth(int) - Method in class org.apache.openjpa.util.ProxyUtilDate
 
setMultiLine(boolean) - Method in class org.apache.openjpa.lib.jdbc.SQLFormatter
If true, then try to parse multi-line SQL statements.
setMultithreaded(boolean) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Whether brokers or their managed objects will be used by multiple concurrent threads.
setMultithreaded(Boolean) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Wrapper for JCA usage of OpenJPAConfiguration.setMultithreaded(boolean).
setMultithreaded(boolean) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setMultithreaded(Boolean) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setMultithreaded(boolean) - Method in interface org.apache.openjpa.kernel.Broker
Whether the broker or its managed instances are used in a multithreaded environment.
setMultithreaded(boolean) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
setMultithreaded(boolean) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
setMultithreaded(boolean) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
setMultithreaded(boolean) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether the entity manager or its managed instances are used in a multithreaded environment.
setName(String) - Method in class org.apache.openjpa.ant.ApplicationIdToolTask
Set the name of the identity class; with this option you must supply exactly one class to run on.
setName(String) - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
setName(String) - Method in interface org.apache.openjpa.datacache.DataCache
Sets a string name to be used to identify this cache to end-user needs.
setName(String) - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
setName(String) - Method in class org.apache.openjpa.jdbc.schema.Column
Set the column's name.
setName(String) - Method in class org.apache.openjpa.jdbc.schema.Constraint
Set the name of the constraint.
setName(String) - Method in class org.apache.openjpa.jdbc.schema.Schema
Set the name of the schema.
setName(String) - Method in class org.apache.openjpa.jdbc.schema.Sequence
Set the name of the sequence.
setName(String) - Method in class org.apache.openjpa.jdbc.schema.Table
Set the name of the table.
setNanos(int) - Method in class org.apache.openjpa.util.ProxyTimestamp
 
setNestedThrowables(Throwable[]) - Method in exception org.apache.openjpa.util.OpenJPAException
The nested throwables.
setNewline(String) - Method in class org.apache.openjpa.lib.jdbc.SQLFormatter
 
setNextSequence(int) - Method in class org.apache.openjpa.util.AbstractChangeTracker
 
setNextSequence(int) - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
setNextSequence(int) - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
setNextSequence(int) - Method in interface org.apache.openjpa.util.ChangeTracker
The maximum element sequence value for this proxy at load time.
setNextVersion(Object) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
setNextVersion(Object) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
setNextVersion(Object) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
setNextVersion(Object) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Set the next version indicator in the datastore pending a successful flush.
setNextVersion(Object) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
setNonJtaDataSource(DataSource) - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
setNonJtaDataSourceName(String) - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
setNonOptimisticVersionCheck(boolean) - Method in class org.apache.openjpa.conf.Compatibility
Whether or not to perform a version check on instances being updated in a datastore transaction.
setNonPCSuperclassCallbacks(int, LifecycleCallbacks[], int) - Method in class org.apache.openjpa.meta.LifecycleMetaData
Set the callbacks for the given event type for non-persistent superclass.
setNontransactionalRead(boolean) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Whether persistent state is accessible outside a transaction by default.
setNontransactionalRead(Boolean) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Wrapper for JCA usage of OpenJPAConfiguration.setNontransactionalRead(boolean).
setNontransactionalRead(boolean) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setNontransactionalRead(Boolean) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setNontransactionalRead(boolean) - Method in interface org.apache.openjpa.kernel.Broker
Whether to allow nontransactional access to persistent state.
setNontransactionalRead(boolean) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
setNontransactionalRead(boolean) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
setNontransactionalRead(boolean) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
setNontransactionalRead(boolean) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether to allow nontransactional access to persistent state.
setNontransactionalWrite(boolean) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Whether persistent state can be modified outside a transaction by default.
setNontransactionalWrite(Boolean) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Wrapper for JCA usage of OpenJPAConfiguration.setNontransactionalWrite(boolean).
setNontransactionalWrite(boolean) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setNontransactionalWrite(Boolean) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setNontransactionalWrite(boolean) - Method in interface org.apache.openjpa.kernel.Broker
Whether to allow nontransactional changes to persistent state.
setNontransactionalWrite(boolean) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
setNontransactionalWrite(boolean) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
setNontransactionalWrite(boolean) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
setNontransactionalWrite(boolean) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether to allow nontransactional changes to persistent state.
setNotNull(boolean) - Method in class org.apache.openjpa.jdbc.schema.Column
Set whether this is a NOT NULL column.
setNull(PreparedStatement, int, int, Column) - Method in class org.apache.openjpa.jdbc.sql.AbstractSQLServerDictionary
 
setNull(PreparedStatement, int, int, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameters to the statement.
setNull(PreparedStatement, int, int, Column) - Method in class org.apache.openjpa.jdbc.sql.FoxProDictionary
 
setNull(PreparedStatement, int, int, Column) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
setNull(Column) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setNull(Column, boolean) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setNull(Column) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setNull(Column, boolean) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setNull(int, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setNull(int, int, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setNull(String, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setNull(String, int, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setNull(int, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setNull(int, int, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setNullableAsObject(boolean) - Method in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
Set whether to represent nullable columns as primitive wrappers.
setNullableAsObject(boolean) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Set whether even nullable columns will be mapped to wrappers rather than primitives.
setNullIndicatorColumnName(String) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default base name for null indicator columns, or null to the mapping's built-in name.
setNullInsertable(int, boolean) - Method in class org.apache.openjpa.jdbc.schema.ColumnIO
Whether this context can insert the given column as null/default in this context.
setNullOnNoLocator(boolean) - Method in class org.apache.openjpa.lib.xml.Location
 
setNullUpdatable(int, boolean) - Method in class org.apache.openjpa.jdbc.schema.ColumnIO
Whether this context can set the given column to null/default in this context.
setNullValue(int) - Method in class org.apache.openjpa.meta.FieldMetaData
How the data store should treat null values for this field: FieldMetaData.NULL_UNSET: no value supplied FieldMetaData.NULL_NONE: leave null values as null in the data store FieldMetaData.NULL_EXCEPTION: throw an exception if this field is null at commit FieldMetaData.NULL_DEFAULT: use the database default if this field is null at commit Defaults to FieldMetaData.NULL_UNSET.
setNumber(PreparedStatement, int, Number, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setNumber(Column, Number) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setNumber(Column, Number) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setNumBroadcastThreads(int) - Method in class org.apache.openjpa.event.TCPRemoteCommitProvider
The number of worker threads that are used for transmitting packets to peers in the cluster.
setObject(int, Object) - Method in interface org.apache.openjpa.enhance.DynamicStorage
Set the object at the given index.
setObject(Column, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy.CustomUpdate
 
setObject(PreparedStatement, int, Object, int, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameters to the statement.
setObject(Column, Object, int, boolean) - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
 
setObject(Column, Object) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setObject(Column, Object) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setObject(Column, Object, int, boolean) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
All set column methods delegate to this one.
setObject(Object) - Method in class org.apache.openjpa.lib.conf.Value
Set this value as an object.
setObject(int, Object, int, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setObject(int, Object, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setObject(int, Object) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setObject(String, Object, int, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setObject(String, Object, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setObject(String, Object) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setObject(int, Object, int, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setObject(int, Object, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setObject(int, Object) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setObjectId(Object) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
setObjectId(Object) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
setObjectId(Object) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
setObjectId(Object) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Set the object id for the managed instance.
setObjectId(Object) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
setObjectIdType(Class, boolean) - Method in class org.apache.openjpa.meta.ClassMetaData
The metadata-specified class to use for the object ID.
setOpenJPATables(boolean) - Method in class org.apache.openjpa.jdbc.ant.MappingToolTask
Set whether to drop OpenJPA tables.
setOpenJPATables(boolean) - Method in class org.apache.openjpa.jdbc.ant.SchemaToolTask
Set whether to drop or reflect on OpenJPA tables.
setOpenJPATables(boolean) - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Whether to generate info on special tables used by OpenJPA components for bookkeeping.
setOpenJPATables(boolean) - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Whether to act on special tables used by OpenJPA components for bookkeeping.
setOptimistic(boolean) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Whether to use optimistic transactions by default.
setOptimistic(Boolean) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Wrapper for JCA usage of OpenJPAConfiguration.setOptimistic(boolean).
setOptimistic(boolean) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setOptimistic(Boolean) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setOptimistic(boolean) - Method in interface org.apache.openjpa.kernel.Broker
Whether to use optimistic transactional semantics.
setOptimistic(boolean) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
setOptimistic(boolean) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
setOptimistic(boolean) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
setOptimistic(boolean) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether to use optimistic transactional semantics.
setOrderColumn(Column) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Field order column, if any.
setOrderColumn(Column) - Method in class org.apache.openjpa.jdbc.meta.FieldMappingInfo
Raw synthetic ordering column.
setOrderColumnIO(ColumnIO) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
I/O information for order column.
setOrderColumnName(String) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default base name for order columns, or null to the mapping's built-in name.
setOrderDeclaration(String) - Method in class org.apache.openjpa.meta.FieldMetaData
String declaring the orderings for this field to be applied on load, or null.
setOrderDirtyObjects(boolean) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
setOrderDirtyObjects(boolean) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
setOrderDirtyObjects(boolean) - Method in interface org.apache.openjpa.kernel.StoreContext
Whether to maintain the order in which objects are dirtied for StoreContext.getDirtyObjects().
setOrderDirtyObjects(boolean) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
setOrderDirtyObjects(boolean) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether dirty objects will be returned in the order they were dirtied.
setOrderLists(boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Whether to order lists and arrays using a dedicated ordering column by default.
setOrders(Order[]) - Method in class org.apache.openjpa.meta.FieldMetaData
The orderings for this field to be applied on load.
setOrphanedKeyAction(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The action to take when an orphaned key is detected.
setOrphanedKeyAction(OrphanedKeyAction) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The action to take when an orphaned key is detected.
setOrphanedKeyAction(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setOrphanedKeyAction(OrphanedKeyAction) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setOuter(boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
setOuter(boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
setOwner(OpenJPAStateManager, int) - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
setOwner(OpenJPAStateManager, int) - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
setOwner(OpenJPAStateManager, int) - Method in interface org.apache.openjpa.util.Proxy
Reset the state of the proxy, and set the owning instance of the proxy and the name of the field it is assigned to.
setOwner(OpenJPAStateManager, int) - Method in class org.apache.openjpa.util.ProxyArrayList
 
setOwner(OpenJPAStateManager, int) - Method in class org.apache.openjpa.util.ProxyGregorianCalendar
 
setOwner(OpenJPAStateManager, int) - Method in class org.apache.openjpa.util.ProxyHashMap
 
setOwner(OpenJPAStateManager, int) - Method in class org.apache.openjpa.util.ProxyHashSet
 
setOwner(OpenJPAStateManager, int) - Method in class org.apache.openjpa.util.ProxyHashtable
 
setOwner(OpenJPAStateManager, int) - Method in class org.apache.openjpa.util.ProxyLinkedList
 
setOwner(OpenJPAStateManager, int) - Method in class org.apache.openjpa.util.ProxyProperties
 
setOwner(OpenJPAStateManager, int) - Method in class org.apache.openjpa.util.ProxySQLDate
 
setOwner(OpenJPAStateManager, int) - Method in class org.apache.openjpa.util.ProxyTime
 
setOwner(OpenJPAStateManager, int) - Method in class org.apache.openjpa.util.ProxyTimestamp
 
setOwner(OpenJPAStateManager, int) - Method in class org.apache.openjpa.util.ProxyTreeMap
 
setOwner(OpenJPAStateManager, int) - Method in class org.apache.openjpa.util.ProxyTreeSet
 
setOwner(OpenJPAStateManager, int) - Method in class org.apache.openjpa.util.ProxyUtilDate
 
setOwner(OpenJPAStateManager, int) - Method in class org.apache.openjpa.util.ProxyVector
 
setPackage(String) - Method in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
Set the package name for the generated classes.
setPackage(String) - Method in class org.apache.openjpa.lib.meta.CFMetaDataSerializer
The default package for objects being serialized.
setPackageName(String) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Set the default package for the generated classes; use null to indicate no package.
setParameter(String, Object) - Method in class org.apache.openjpa.lib.util.ParameterTemplate
Set the value for the given parameter.
setParameter(String, Object) - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
 
setParameter(String, Date, TemporalType) - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
 
setParameter(String, Calendar, TemporalType) - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
 
setParameter(int, Object) - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
 
setParameter(int, Date, TemporalType) - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
 
setParameter(int, Calendar, TemporalType) - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
 
setParameter(int, Calendar, TemporalType) - Method in class org.apache.openjpa.persistence.QueryImpl
 
setParameter(int, Date, TemporalType) - Method in class org.apache.openjpa.persistence.QueryImpl
 
setParameter(int, Object) - Method in class org.apache.openjpa.persistence.QueryImpl
 
setParameter(String, Calendar, TemporalType) - Method in class org.apache.openjpa.persistence.QueryImpl
 
setParameter(String, Date, TemporalType) - Method in class org.apache.openjpa.persistence.QueryImpl
 
setParameter(String, Object) - Method in class org.apache.openjpa.persistence.QueryImpl
 
setParameters(PreparedStatement) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Populate the parameters of an existing PreparedStatement with values from this buffer.
setParameters(Map) - Method in class org.apache.openjpa.lib.util.ParameterTemplate
Set the values for all the parameters in the given map.
setParameters(Map) - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Set parameters.
setParameters(Object...) - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Set parameters.
setParameters(Object...) - Method in class org.apache.openjpa.persistence.QueryImpl
 
setParameters(Map) - Method in class org.apache.openjpa.persistence.QueryImpl
 
setParent(Select, String) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
setParent(Select, String) - Method in interface org.apache.openjpa.jdbc.sql.Select
Turn this select into a subselect of the given instance.
setParent(Select, String) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
setParseComments(boolean) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Whether to parse element comments.
setParseText(boolean) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Whether to parse element text.
setPCSuperclass(Class) - Method in class org.apache.openjpa.meta.ClassMetaData
The persistence capable superclass of the described type.
setPCSuperclassMetaData(ClassMetaData) - Method in class org.apache.openjpa.meta.ClassMetaData
The metadata for this class' superclass.
setPersistenceProviderClassName(String) - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
setPersistenceUnitName(String) - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
setPersistenceUnitRootUrl(URL) - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
setPersistenceXmlFileUrl(URL) - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
The location of the persistence.xml resource.
setPolymorphic(int) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
setPolymorphic(int) - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
The degree to which this relation is polymorphic.
setPolymorphic(int) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
setPopulateDataCache(boolean) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
setPopulateDataCache(boolean) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
setPopulateDataCache(boolean) - Method in interface org.apache.openjpa.kernel.StoreContext
Whether to populate the store cache with objects used by this transaction.
setPopulateStoreCache(boolean) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
setPopulateStoreCache(boolean) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether to populate the store cache with objects used by this transaction.
setPort(int) - Method in class org.apache.openjpa.event.TCPRemoteCommitProvider
The port that this provider should listen on.
setPostLoad(boolean) - Method in class org.apache.openjpa.meta.FetchGroup
Whether loading this fetch group causes a post-load callback on the loaded instance.
setPreFlush(boolean) - Method in class org.apache.openjpa.kernel.InMemorySavepointManager
Set whether to call Broker.preFlush() when a savepoint is set.
setPrettyPrint(boolean) - Method in class org.apache.openjpa.lib.jdbc.LoggingConnectionDecorator
If set to true, pretty-print SQL by running it through SQLFormatter.prettyPrint(java.lang.Object).
setPrettyPrintLineLength(int) - Method in class org.apache.openjpa.lib.jdbc.LoggingConnectionDecorator
The number of characters to print per line when pretty-printing of SQL is enabled.
setPrimaryKey(OpenJPAStateManager) - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
 
setPrimaryKey(ColumnIO, OpenJPAStateManager) - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
 
setPrimaryKey(OpenJPAStateManager) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the primary key to represent the given object.
setPrimaryKey(ColumnIO, OpenJPAStateManager) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the primary key to represent the given object.
setPrimaryKey(OpenJPAStateManager) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setPrimaryKey(ColumnIO, OpenJPAStateManager) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setPrimaryKey(boolean) - Method in class org.apache.openjpa.meta.FieldMetaData
Whether this is a primary key field.
setPrimaryKeyColumn(String) - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
The name of the table's primary key column.
setPrimaryKeyColumn(String) - Method in class org.apache.openjpa.jdbc.meta.SequenceMapping
Name of primary key column, if any.
setPrimaryKeyColumn(String) - Method in class org.apache.openjpa.jdbc.schema.TableSchemaFactory
The name of the primary key column on the schema definition table.
setPrimaryKeyColumnName(String) - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
The name of the primary key column.
setPrimaryKeyColumns(Column[]) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
The columns this mapping uses to uniquely identify an object.
setPrimaryKeyIndex(int) - Method in class org.apache.openjpa.meta.FieldMetaData
The absolute primary key index for this field, or -1 if not a primary key.
setPrimaryKeyOnJoin(boolean) - Method in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
Set whether to allow primary keys on join tables.
setPrimaryKeyOnJoin(boolean) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Set to true if join tables are allowed to have primary keys, false if all primary key tables will be mapped as persistent classes.
setPrimaryKeys(boolean) - Method in class org.apache.openjpa.jdbc.ant.MappingToolTask
Set whether to generate primary key information.
setPrimaryKeys(boolean) - Method in class org.apache.openjpa.jdbc.ant.SchemaToolTask
Set whether to generate primary key information.
setPrimaryKeys(boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Whether primary keys on existing tables should be manipulated.
setPrimaryKeys(boolean) - Method in class org.apache.openjpa.jdbc.schema.LazySchemaFactory
 
setPrimaryKeys(boolean) - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Set whether primary keys should be generated.
setPrimaryKeys(boolean) - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Whether primary keys on existing tables should be manipulated.
setPrimaryKeySchemaName(String) - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
The name of the primary key table's schema.
setPrimaryKeyTableName(String) - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
The name of the primary key table.
setPrimaryKeyValue(String) - Method in class org.apache.openjpa.jdbc.kernel.ValueTableJDBCSeq
The primary key value for this row.
setPrimaryKeyValue(String) - Method in class org.apache.openjpa.jdbc.meta.SequenceMapping
Primary key value, if not auto-determined.
setProductName(String) - Method in interface org.apache.openjpa.lib.conf.Configuration
Set the product name.
setProductName(String) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
setProperties(String) - Method in class org.apache.openjpa.conf.RemoteCommitProviderValue
 
setProperties(String) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
This method loads the named resource as a properties file.
setProperties(String[]) - Method in class org.apache.openjpa.lib.conf.PluginListValue
The plugin properties.
setProperties(String) - Method in class org.apache.openjpa.lib.conf.PluginValue
The plugin properties.
setPropertiesFile(File) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
This method loads the named file as a properties file.
setProperty(String) - Method in class org.apache.openjpa.lib.conf.Value
The property name that will be used when setting or getting this value in a Map.
setProperty(String, String) - Method in class org.apache.openjpa.lib.util.FormatPreservingProperties
 
setProperty(String, String) - Method in class org.apache.openjpa.lib.util.TypedProperties
Overrides Properties.setProperty(String,String) to remove the key if the given value is null.
setProperty(String, boolean) - Method in class org.apache.openjpa.lib.util.TypedProperties
Set the given key to a string version of the given value.
setProperty(String, double) - Method in class org.apache.openjpa.lib.util.TypedProperties
Set the given key to a string version of the given value.
setProperty(String, float) - Method in class org.apache.openjpa.lib.util.TypedProperties
Set the given key to a string version of the given value.
setProperty(String, int) - Method in class org.apache.openjpa.lib.util.TypedProperties
Set the given key to a string version of the given value.
setProperty(String, long) - Method in class org.apache.openjpa.lib.util.TypedProperties
Set the given key to a string version of the given value.
setProperty(String, String) - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
setProperty(String, String) - Method in class org.apache.openjpa.util.ProxyProperties
 
setProvider(RemoteCommitProvider) - Method in class org.apache.openjpa.conf.RemoteCommitProviderValue
The cached provider.
setProxyManager(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The plugin string for the ProxyManager to use for second class object proxies.
setProxyManager(ProxyManager) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The ProxyManager to use.
setProxyManager(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setProxyManager(ProxyManager) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setProxyTemplate(Class, ProxyCollection) - Method in class org.apache.openjpa.util.ProxyManagerImpl
Add a supported proxy collection type.
setProxyTemplate(Class, ProxyMap) - Method in class org.apache.openjpa.util.ProxyManagerImpl
Add a supported proxy map type.
setProxyType(Class) - Method in class org.apache.openjpa.meta.FieldMetaData
The type this field was initialized with, and therefore the type to use for proxies when loading data into this field.
setQuery(Object) - Method in class org.apache.openjpa.datacache.QueryCacheStoreQuery
 
setQuery(Object) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery
 
setQuery(Object) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
setQuery(Object) - Method in class org.apache.openjpa.kernel.ExpressionStoreQuery
Allow direct setting of parsed state for facades that do parsing.
setQuery(Object) - Method in interface org.apache.openjpa.kernel.Query
The query string or template.
setQuery(Object) - Method in class org.apache.openjpa.kernel.QueryImpl
 
setQuery(Object) - Method in interface org.apache.openjpa.kernel.StoreQuery
This is invoked when the user or a facade creates a new query with an object that the system does not recognize.
setQueryCache(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The plugin to use for level-2 data store query caching.
setQueryCache(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setQueryCache(boolean) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
setQueryCache(boolean) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Control whether or not query caching is enabled.
setQueryCache(boolean) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
setQueryCompilationCache(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Configuration settings for the query compilation cache to use.
setQueryCompilationCache(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setQueryExpressions(QueryExpressions) - Method in interface org.apache.openjpa.kernel.exps.Subquery
Set the parsed subquery.
setQueryResultCache(boolean) - Method in interface org.apache.openjpa.persistence.FetchPlan
Control whether or not query caching is enabled.
setQueryResultCache(boolean) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
setQueryString(String) - Method in class org.apache.openjpa.meta.QueryMetaData
The full query string, or null if none.
setQueryTimeout(int) - Method in class org.apache.openjpa.lib.jdbc.ConfiguringConnectionDecorator
The number of seconds to wait for a query to execute before terminating it.
setQueryTimeout(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setQueryTimeout(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setQueryTimeout(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
setQuotedNumbersInQueries(boolean) - Method in class org.apache.openjpa.conf.Compatibility
Whether to interpret quoted numbers in query strings as numbers.
setRange(long, long) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
setRange(long, long) - Method in interface org.apache.openjpa.jdbc.sql.Select
Set the result range for this select.
setRange(long, long) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
setRange(long, long) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
setRange(long, long) - Method in interface org.apache.openjpa.kernel.QueryContext
Set the range of results to return.
setRange(long, long) - Method in class org.apache.openjpa.kernel.QueryImpl
 
setRaw(Column, String) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set a DB understood value for the given column.
setRaw(Column, String) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setReadLockLevel(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The default read lock level to use during non-optimistic transactions.
setReadLockLevel(int) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The numeric read lock level.
setReadLockLevel(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setReadLockLevel(int) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setReadLockLevel(int) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
setReadLockLevel(int) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
The lock level to use for locking loaded objects.
setReadLockLevel(int) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
setReadLockMode(LockModeType) - Method in interface org.apache.openjpa.persistence.FetchPlan
The lock level to use for locking loaded objects.
setReadLockMode(LockModeType) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
setReadOnly(boolean) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
setReadOnly(boolean) - Method in interface org.apache.openjpa.kernel.QueryContext
Whether the query has been marked read-only.
setReadOnly(boolean) - Method in class org.apache.openjpa.kernel.QueryImpl
 
setReadOnly(boolean) - Method in interface org.apache.openjpa.lib.conf.Configuration
Lock down the configuration's state.
setReadOnly(boolean) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
setReadOnly(boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
setReadOnly(boolean) - Method in class org.apache.openjpa.meta.QueryMetaData
Whether the query has been marked read-only.
setReadSchema(boolean) - Method in class org.apache.openjpa.jdbc.ant.MappingToolTask
Set whether the MappingTool should read the full schema.
setReadSchema(boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Set to true to read the entire schema before mapping.
setRecord(boolean) - Method in class org.apache.openjpa.jdbc.ant.SchemaToolTask
Set whether the SchemaTool should record to the schema factory.
setRecoveryTimeMillis(int) - Method in class org.apache.openjpa.event.TCPRemoteCommitProvider
The number of milliseconds to wait before retrying to reconnect to a peer after it becomes unreachable.
setRecursionDepth(FieldMetaData, int) - Method in class org.apache.openjpa.meta.FetchGroup
Recursion depth for the given field.
setRef(PreparedStatement, int, Ref, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setRef(int, Ref) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setRef(int, Ref) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setRelation(ClassMapping, int, Joins) - Method in class org.apache.openjpa.jdbc.sql.Join
When joining a relation, set target type and how to deal with subclasses.
setRelationId(boolean) - Method in class org.apache.openjpa.jdbc.schema.Column
Whether this column stores some form of serialized identity value for a related record.
setRelationId(Column, OpenJPAStateManager, RelationId) - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
 
setRelationId(Column, OpenJPAStateManager, RelationId) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column to the identity of given instance, using the given callback to create the column value.
setRelationId(Column, OpenJPAStateManager, RelationId) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setRelationId(Column, OpenJPAStateManager, RelationId) - Method in class org.apache.openjpa.jdbc.sql.SecondaryRow
 
setRemote(int, Object) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
setRemote(int, Object) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
setRemote(int, Object) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
setRemote(int, Object) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Set the given field to the given value.
setRemote(int, Object) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
setRemoteCommitEventManager(RemoteCommitEventManager) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The remote event manager that manages this configuration's remote event listeners.
setRemoteCommitEventManager(RemoteCommitEventManager) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setRemoteCommitEventManager(RemoteCommitEventManager) - Method in class org.apache.openjpa.event.AbstractRemoteCommitProvider
 
setRemoteCommitEventManager(RemoteCommitEventManager) - Method in interface org.apache.openjpa.event.RemoteCommitProvider
Set the "owning" remote event manager to notify when remote events are received from remote sources.
setRemoteCommitProvider(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The plugin to use for remote commit notification.
setRemoteCommitProvider(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setRepository(MappingRepository) - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Set the repository to use to access mapping information.
setRepository(MetaDataRepository) - Method in class org.apache.openjpa.jdbc.meta.MetaDataPlusMappingFactory
 
setRepository(MappingRepository) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Set the repository to use.
setRepository(MetaDataRepository) - Method in class org.apache.openjpa.meta.AbstractMetaDataFactory
 
setRepository(MetaDataRepository) - Method in class org.apache.openjpa.meta.DelegatingMetaDataFactory
 
setRepository(MetaDataRepository) - Method in interface org.apache.openjpa.meta.MetaDataFactory
Set the repository to load metadata into.
setRepository(MetaDataRepository) - Method in class org.apache.openjpa.meta.MetaDataTool
The repository to use to hold metadata.
setRepository(MetaDataRepository) - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
setRepository(MetaDataRepository) - Method in class org.apache.openjpa.persistence.AnnotationPersistenceMetaDataParser
Set the metadata repository for this parser.
setRepository(MetaDataRepository) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Set the metadata repository for this parser.
setRequiresExtent(boolean) - Method in class org.apache.openjpa.meta.ClassMetaData
Whether the type requires extent management.
setResolve(int) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
Resolve mode.
setResolve(int, boolean) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
Resolve mode.
setResolve(int) - Method in class org.apache.openjpa.jdbc.meta.Version
Resolve mode.
setResolve(int, boolean) - Method in class org.apache.openjpa.jdbc.meta.Version
Resolve mode.
setResolve(int) - Method in class org.apache.openjpa.meta.ClassMetaData
The resolve mode for this metadata.
setResolve(int, boolean) - Method in class org.apache.openjpa.meta.ClassMetaData
The resolve mode for this metadata.
setResolve(int) - Method in class org.apache.openjpa.meta.FieldMetaData
Resolve mode for this field.
setResolve(int, boolean) - Method in class org.apache.openjpa.meta.FieldMetaData
Resolve mode for this field.
setResolve(int) - Method in class org.apache.openjpa.meta.MetaDataRepository
The metadata resolution mode.
setResolve(int, boolean) - Method in class org.apache.openjpa.meta.MetaDataRepository
The metadata resolution mode.
setResolve(int) - Method in interface org.apache.openjpa.meta.ValueMetaData
Resolve mode for metadata.
setResolve(int, boolean) - Method in interface org.apache.openjpa.meta.ValueMetaData
Resolve mode for metadata.
setResolve(int) - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
setResolve(int, boolean) - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
setResources(Collection) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Set of resource paths of metadata files or jars supplied by user.
setResources(String) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Set of semicolon-separated resource paths of metadata files or jars supplied by user via auto-configuration.
setRestoreFieldState(boolean) - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSavepointManager
Set whether to retain in-memory copies of field values for restore on rollback.
setRestoreState(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Whether to restore initial state on rollback by default.
setRestoreState(int) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Whether to restore initial state on rollback by default.
setRestoreState(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setRestoreState(int) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setRestoreState(int) - Method in interface org.apache.openjpa.kernel.Broker
Whether to restore an object's original state on rollback.
setRestoreState(int) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
setRestoreState(int) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
setRestoreState(int) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
setRestoreState(int) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether to restore an object's original state on rollback.
setResultClass(Class) - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Query result element type.
setResultClass(Class) - Method in class org.apache.openjpa.persistence.QueryImpl
 
setResultMapping(Class, String) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
setResultMapping(Class, String) - Method in interface org.apache.openjpa.kernel.QueryContext
Name and scope of a mapping from the result data to its object representation.
setResultMapping(Class, String) - Method in class org.apache.openjpa.kernel.QueryImpl
 
setResultSetType(String) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The JDBC result set type.
setResultSetType(int) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Set the result set constant type.
setResultSetType(String) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setResultSetType(int) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setResultSetType(int) - Method in class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
 
setResultSetType(int) - Method in interface org.apache.openjpa.jdbc.kernel.JDBCFetchConfiguration
The result set type to use as a constant from ResultSet.
setResultSetType(int) - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
setResultSetType(int) - Method in interface org.apache.openjpa.persistence.jdbc.JDBCFetchPlan
Type of JDBC result set to use for query results.
setResultSetType(int) - Method in class org.apache.openjpa.persistence.jdbc.JDBCFetchPlanImpl
 
setResultType(Class) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
setResultType(Class) - Method in interface org.apache.openjpa.kernel.QueryContext
Specify the type of object in which the result of evaluating this query.
setResultType(Class) - Method in class org.apache.openjpa.kernel.QueryImpl
 
setResultType(Class) - Method in class org.apache.openjpa.meta.QueryMetaData
The query result class, or null if none.
setRetain(boolean) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager.RefCountConnection
 
setRetainState(boolean) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Whether to retain state after a transaction by default.
setRetainState(Boolean) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Wrapper for JCA usage of OpenJPAConfiguration.setRetainState(boolean).
setRetainState(boolean) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setRetainState(Boolean) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setRetainState(boolean) - Method in interface org.apache.openjpa.kernel.Broker
Whether objects retain their persistent state on transaction commit.
setRetainState(boolean) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
setRetainState(boolean) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
setRetainState(boolean) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
setRetainState(boolean) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether objects retain their persistent state on transaction commit.
setRetryClassRegistration(boolean) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Whether to warn and defer registration instead of throwing an exception when a registered persistent class cannot be processed.
setRetryClassRegistration(Boolean) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Wrapper for JCA usage of OpenJPAConfiguration.setRetryClassRegistration(boolean).
setRetryClassRegistration(boolean) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setRetryClassRegistration(Boolean) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setRollbackOnly() - Method in interface org.apache.openjpa.kernel.Broker
Mark the current transaction for rollback.
setRollbackOnly() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
setRollbackOnly() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
setRollbackOnly() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
setRollbackOnly() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Mark the current transaction for rollback.
setRootClasses(Collection) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
setRootClasses(Collection) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Root classes for recursive operations.
setRootClasses(Collection) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
setRootInstances(Collection) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
setRootInstances(Collection) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Root instances for recursive operations.
setRootInstances(Collection) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
setSavepoint(String) - Method in interface org.apache.openjpa.kernel.Broker
Set a transactional savepoint where operations after this savepoint will be rolled back.
setSavepoint(String) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
setSavepoint(String) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
setSavepoint() - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
setSavepoint(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
setSavepoint(String) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
setSavepoint(String) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Set a transactional savepoint where operations after this savepoint will be rolled back.
setSavepointManager(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The plugin to use for savepoint management.
setSavepointManager(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setSchema(String) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Default schema for unqualified tables.
setSchema(String) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setSchemaAction(MappingToolTask.SchemaAction) - Method in class org.apache.openjpa.jdbc.ant.MappingToolTask
Set the enumerated SchemaTool action type.
setSchemaAction(String) - Method in class org.apache.openjpa.jdbc.meta.MappingTool
The schema modification policy, or none.
setSchemaColumn(String) - Method in class org.apache.openjpa.jdbc.schema.TableSchemaFactory
The name of the schema column on the schema definition table.
setSchemaFactory(String) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The plugin string for the SchemaFactory to use to provide schema information during system initialization.
setSchemaFactory(SchemaFactory) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The SchemaFactory to use for schema information.
setSchemaFactory(String) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setSchemaFactory(SchemaFactory) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setSchemaFile(String) - Method in class org.apache.openjpa.jdbc.ant.MappingToolTask
Set the output file for an XML representation of the planned schema.
setSchemaGroup(SchemaGroup) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Representation of the database schema.
setSchemaGroup(SchemaGroup) - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Set the schema to use in mapping.
setSchemaGroup(SchemaGroup) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Set the schema to reverse map.
setSchemaGroup(SchemaGroup) - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Set the schema group to add generated schemas to.
setSchemaGroup(SchemaGroup) - Method in interface org.apache.openjpa.jdbc.schema.SchemaParser
Set the current schema group; this clears all state from the last group.
setSchemaGroup(SchemaGroup) - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Set the schema group the tool will act on.
setSchemaGroup(SchemaGroup) - Method in class org.apache.openjpa.jdbc.schema.XMLSchemaParser
 
setSchemaName(String) - Method in class org.apache.openjpa.jdbc.schema.Column
The column's schema name.
setSchemaName(String) - Method in class org.apache.openjpa.jdbc.schema.Constraint
Set the column table's schema name.
setSchemaName(String) - Method in class org.apache.openjpa.jdbc.schema.Sequence
The sequence's schema name.
setSchemaName(String) - Method in class org.apache.openjpa.jdbc.schema.Table
The table's schema name.
setSchemas(String) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Comma-separated list of modifiable schemas for persistent instances.
setSchemas(String[]) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Modifiable schema components.
setSchemas(String) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setSchemas(String[]) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setSchemaTool(SchemaTool) - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Set the schema tool to use for schema modification.
setSchemaWriter(Writer) - Method in class org.apache.openjpa.jdbc.meta.MappingTool
The stream to export the planned schema to as an XML document.
setScope(Class) - Method in class org.apache.openjpa.lib.conf.Value
A class defining the scope in which this value is defined.
setScoreBeforeFieldName(boolean) - Method in class org.apache.openjpa.lib.util.CodeFormat
Whether to place an underscore before private field names.
setSecondaryTableJoinColumns(String, List) - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
Declare the given class-level join.
setSeconds(int) - Method in class org.apache.openjpa.util.ProxySQLDate
 
setSeconds(int) - Method in class org.apache.openjpa.util.ProxyTime
 
setSeconds(int) - Method in class org.apache.openjpa.util.ProxyTimestamp
 
setSeconds(int) - Method in class org.apache.openjpa.util.ProxyUtilDate
 
setSelect(SelectImpl) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
Select for this result.
setSequence(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Plugin string for the default system Seq.
setSequence(Seq) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The default system sequence.
setSequence(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setSequence(Seq) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setSequence(String) - Method in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
The sequence name.
setSequence(ClassMapping, TableJDBCSeq.Status, int, boolean, Connection) - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
Grabs the next handful of sequence numbers.
setSequence(String) - Method in class org.apache.openjpa.meta.SequenceMetaData
Native sequence name.
setSequenceColumn(String) - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
The name of the column that holds the sequence value.
setSequenceColumn(String) - Method in class org.apache.openjpa.jdbc.meta.SequenceMapping
Name of sequence column, if any.
setSequenceFactory(SequenceMetaData.SequenceFactory) - Method in class org.apache.openjpa.meta.SequenceMetaData
A factory to transform spec sequences produced by user factories into the OpenJPA sequence type.
setSequenceName(String) - Method in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
Deprecated. Use NativeJDBCSeq.setSequence(java.lang.String). Retained for backwards-compatibility for auto-configuration.
setSequencePlugin(String) - Method in class org.apache.openjpa.meta.SequenceMetaData
Plugin string describing the Seq.
setSequences(boolean) - Method in class org.apache.openjpa.jdbc.ant.MappingToolTask
Set whether the MappingTool should manipulate sequences.
setSequences(boolean) - Method in class org.apache.openjpa.jdbc.ant.SchemaToolTask
Set whether the SchemaTool should manipulate sequences.
setSequences(boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingTool
Whether to manipulate sequences.
setSequences(boolean) - Method in class org.apache.openjpa.jdbc.schema.SchemaGenerator
Set whether sequences should be generated.
setSequences(boolean) - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
Whether sequences should be manipulated.
setSerializeAnnotations(boolean) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Whether to serialize content originally specified in annotations.
setSerialized(boolean) - Method in class org.apache.openjpa.meta.FieldMetaData
 
setSerialized(boolean) - Method in interface org.apache.openjpa.meta.ValueMetaData
Whether this value is serialized when stored.
setSerialized(boolean) - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
setShort(int, short) - Method in interface org.apache.openjpa.enhance.DynamicStorage
Set the short at the given index.
setShort(PreparedStatement, int, short, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setShort(Column, short) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setShort(Column, short) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setShort(int, short) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setShort(String, short) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setShort(int, short) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setSingleResult(boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
setSingleResult(boolean) - Method in interface org.apache.openjpa.jdbc.sql.Union
Whether this union will return at most a single result.
setSize(int) - Method in class org.apache.openjpa.jdbc.kernel.SelectResultObjectProvider
Allow subclasses that know the size to set it; otherwise we calculate it internally.
setSize(int) - Method in class org.apache.openjpa.jdbc.schema.Column
Set the column's size.
setSoftReferenceSize(int) - Method in class org.apache.openjpa.datacache.ConcurrentDataCache
Sets the maximum number of unpinned objects to keep soft references to.
setSoftReferenceSize(int) - Method in class org.apache.openjpa.datacache.ConcurrentQueryCache
Sets the maximum number of unpinned objects to keep soft references to.
setSoftReferenceSize(int) - Method in class org.apache.openjpa.util.CacheMap
The maximum number of soft references to maintain, or -1 for no limit.
setSource(File, int) - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
 
setSource(File, Object, int) - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping
 
setSource(File, int) - Method in class org.apache.openjpa.jdbc.schema.Sequence
 
setSource(File, int) - Method in class org.apache.openjpa.jdbc.schema.Table
 
setSource(File, int) - Method in class org.apache.openjpa.meta.ClassMetaData
 
setSource(File, int) - Method in class org.apache.openjpa.meta.NonPersistentMetaData
 
setSource(File, Object, int) - Method in class org.apache.openjpa.meta.QueryMetaData
 
setSource(File, Object, int) - Method in class org.apache.openjpa.meta.SequenceMetaData
 
setSource(String) - Method in class org.apache.openjpa.persistence.PersistenceProductDerivation.ConfigurationProviderImpl
Set the source of information in this provider.
setSourceFile(ClassMetaData, File) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Set the current source file of the given metadata.
setSourceFile(SequenceMetaData, File) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Set the current source file of the given metadata.
setSourceIsSystemId(boolean) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Whether to use the source name as the XML system id.
setSourceMode(int) - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping
The source mode of this query result.
setSourceMode(int) - Method in class org.apache.openjpa.meta.ClassMetaData
The source mode this metadata has been loaded under.
setSourceMode(int, boolean) - Method in class org.apache.openjpa.meta.ClassMetaData
The source mode this metadata has been loaded under.
setSourceMode(int) - Method in class org.apache.openjpa.meta.MetaDataRepository
The source mode determining what metadata to load.
setSourceMode(int, boolean) - Method in class org.apache.openjpa.meta.MetaDataRepository
The source mode determining what metadata to load.
setSourceMode(int) - Method in class org.apache.openjpa.meta.QueryMetaData
The source mode of this query.
setSpaceBeforeParen(boolean) - Method in class org.apache.openjpa.lib.util.CodeFormat
Whether to place a space before parentheses.
setSpaceInParen(boolean) - Method in class org.apache.openjpa.lib.util.CodeFormat
Whether to place a space within parentheses.
setSpecification(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Set the specification that this configuration should use for the various properties that need to have different defaults for different spec environments.
setSpecification(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setSQLFactory(String) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The SQL factory to use for SQL constructs.
setSQLFactory(SQLFactory) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The SQL factory to use for SQL constructs.
setSQLFactory(String) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setSQLFactory(SQLFactory) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setSQLFile(String) - Method in class org.apache.openjpa.jdbc.ant.MappingToolTask
Set the output file we want the MappingTool to write a SQL script to.
setSQLLog(Log) - Method in class org.apache.openjpa.lib.jdbc.DataSourceLogs
The log to write SQL messages to.
setStorageGenerator(PCDataGenerator) - Method in interface org.apache.openjpa.enhance.PCDataGenerator.DynamicPCData
 
setStore(JDBCStore) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
Optional store manager used to deserialize blobs containing references to persistent objects.
setStoreDirectory(File) - Method in class org.apache.openjpa.jdbc.meta.MetaDataPlusMappingFactory
 
setStoreDirectory(File) - Method in class org.apache.openjpa.meta.AbstractMetaDataFactory
 
setStoreDirectory(File) - Method in class org.apache.openjpa.meta.DelegatingMetaDataFactory
 
setStoreDirectory(File) - Method in interface org.apache.openjpa.meta.MetaDataFactory
Base directory for storing metadata.
setStoreDirectory(File) - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
setStoreEnumOrdinal(boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Whether to store enums as the ordinal value rather than the enum name.
setStoreMode(int) - Method in class org.apache.openjpa.jdbc.meta.MetaDataPlusMappingFactory
 
setStoreMode(int) - Method in class org.apache.openjpa.meta.AbstractMetaDataFactory
 
setStoreMode(int) - Method in class org.apache.openjpa.meta.DelegatingMetaDataFactory
 
setStoreMode(int) - Method in interface org.apache.openjpa.meta.MetaDataFactory
Storage mode.
setStoreMode(int) - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
setStoreOrdinal(boolean) - Method in class org.apache.openjpa.jdbc.meta.strats.EnumValueHandler
Whether to store the enum value as its ordinal.
setStoreUnmappedObjectIdString(boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Whether to store a relation to an unmapped class by stringifying the oid of the related object, rather than storing primary key values.
setStrategy(ClassStrategy, Boolean) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
The strategy used to map this mapping.
setStrategy(DiscriminatorStrategy, Boolean) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
The strategy used for class discrimination.
setStrategy(FieldStrategy, Boolean) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
The strategy used to map this mapping.
setStrategy(String) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Mapping strategy name.
setStrategy(VersionStrategy, Boolean) - Method in class org.apache.openjpa.jdbc.meta.Version
The strategy used for versioning.
setStrategyInstaller(StrategyInstaller) - Method in class org.apache.openjpa.jdbc.meta.MappingRepository
Installs mapping strategies on components.
setStream(PrintStream) - Method in class org.apache.openjpa.lib.log.LogFactoryImpl
The stream to write to.
setStrict(boolean) - Method in class org.apache.openjpa.jdbc.meta.MetaDataPlusMappingFactory
 
setStrict(boolean) - Method in class org.apache.openjpa.meta.AbstractMetaDataFactory
 
setStrict(boolean) - Method in class org.apache.openjpa.meta.DelegatingMetaDataFactory
 
setStrict(boolean) - Method in interface org.apache.openjpa.meta.MetaDataFactory
If true, I/O's must exactly obey the mode directives given, and may not load additional information.
setStrict(boolean) - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
setStrictIdentityValues(boolean) - Method in class org.apache.openjpa.conf.Compatibility
Whether to require exact identity value types when creating object ids from a class and value.
setString(String) - Method in class org.apache.openjpa.conf.RemoteCommitProviderValue
 
setString(PreparedStatement, int, String, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setString(PreparedStatement, int, String, Column) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
setString(Column, String) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setString(Column, String) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setString(String) - Method in class org.apache.openjpa.lib.conf.PluginListValue
Override to recognize aliases of the plugin name without the attached properties string.
setString(String) - Method in class org.apache.openjpa.lib.conf.PluginValue
 
setString(String) - Method in class org.apache.openjpa.lib.conf.Value
Set this value from the given string.
setString(int, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setString(String, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setString(int, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setSubclasses(boolean) - Method in interface org.apache.openjpa.persistence.OpenJPAQuery
Whether subclasses are included in the query results.
setSubclasses(boolean) - Method in class org.apache.openjpa.persistence.QueryImpl
 
setSubclassesLoaded(boolean) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
Whether this Discriminator has loaded subclasses yet.
setSubclassFetchMode(String) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Specifies the default subclass fetch mode to use.
setSubclassFetchMode(int) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Set the subclass fetch mode as one of the following symbolic constants: EagerFetchModes.EAGER_NONE EagerFetchModes.EAGER_JOIN EagerFetchModes.EAGER_PARALLEL
setSubclassFetchMode(String) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setSubclassFetchMode(int) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setSubclassFetchMode(int) - Method in class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
 
setSubclassFetchMode(int) - Method in interface org.apache.openjpa.jdbc.kernel.JDBCFetchConfiguration
Set the subclass fetch mode.
setSubclassFetchMode(int) - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
setSubclassFetchMode(int) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
The subclass fetch mode, as one of the eager constants in JDBCFetchConfiguration.
setSubclassFetchMode(int) - Method in interface org.apache.openjpa.persistence.jdbc.JDBCFetchPlan
Eager fetch mode in loading subclasses.
setSubclassFetchMode(int) - Method in class org.apache.openjpa.persistence.jdbc.JDBCFetchPlanImpl
 
setSubclassStrategy(String) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default subclass strategy alias.
setSubselect(String) - Method in interface org.apache.openjpa.jdbc.sql.Joins
Set the subquery alias.
setSubselect(String) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
setSubselect(String) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
setSuffix(String) - Method in class org.apache.openjpa.ant.ApplicationIdToolTask
Set a suffix to append to persistent classes to form their identity class name.
setSuffix(String) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Expected suffix for metadata resources, or null if unknown.
setSynchronization(Synchronization) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
setSynchronizeMappings(String) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Whether OpenJPA should try to automatically refresh O/R mapping information and the database schema.
setSynchronizeMappings(String) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setSyncMappingInfo(boolean) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer
Whether to automatically synchronize mapping info with data available from mapped components before serialization.
setSyncWithManagedTransactions(boolean) - Method in interface org.apache.openjpa.kernel.Broker
Whether to check for a global transaction upon every managed, non-transactional operation.
setSyncWithManagedTransactions(boolean) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
setSyncWithManagedTransactions(boolean) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
setSyncWithManagedTransactions(boolean) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
setSyncWithManagedTransactions(boolean) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Whether to check for a global transaction upon every managed, non-transactional operation.
setTable(String) - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
The sequence table name.
setTable(Table) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
The mapping's primary table.
setTable(String) - Method in class org.apache.openjpa.jdbc.meta.SequenceMapping
Name of sequence table, if any.
setTable(String) - Method in class org.apache.openjpa.jdbc.schema.TableSchemaFactory
The name of the schema definition table.
setTableName(String) - Method in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
Deprecated. Retained for backwards-compatibility for auto-configuration.
setTableName(String) - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
Deprecated. Use TableJDBCSeq.setTable(java.lang.String). Retained for backwards-compatibility with auto-configuration.
setTableName(String) - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
The given table name.
setTableName(String) - Method in class org.apache.openjpa.jdbc.meta.FieldMappingInfo
The user-supplied name of the table for this field.
setTableName(String) - Method in class org.apache.openjpa.jdbc.schema.Column
The column's table name.
setTableName(String) - Method in class org.apache.openjpa.jdbc.schema.Constraint
Set the column's table name.
setTableName(String) - Method in class org.apache.openjpa.jdbc.schema.TableSchemaFactory
Deprecated. Use TableSchemaFactory.setTable(java.lang.String). Retained for backwards-compatible auto-configuration.
setTabSpaces(int) - Method in class org.apache.openjpa.lib.util.CodeFormat
The number of spaces to use for tabs; 0 means to use actual tab characters.
setTarget(Instruction, Collection) - Method in class org.apache.openjpa.enhance.PCDataGenerator
Set the collection of JumpInstructions to the given instruction, clearing the collection in the process.
setTarget(String) - Method in class org.apache.openjpa.jdbc.schema.Column
The name of the column this column joins to, if any.
setTargetField(String) - Method in class org.apache.openjpa.jdbc.schema.Column
The name of the field this column joins to, if any.
setTime(PreparedStatement, int, Time, Calendar, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setTime(Column, Time, Calendar) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setTime(Column, Time, Calendar) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setTime(int, Time) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setTime(int, Time, Calendar) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setTime(String, Time) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setTime(String, Time, Calendar) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setTime(int, Time) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setTime(int, Time, Calendar) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setTime(long) - Method in class org.apache.openjpa.util.ProxySQLDate
 
setTime(long) - Method in class org.apache.openjpa.util.ProxyTime
 
setTime(long) - Method in class org.apache.openjpa.util.ProxyTimestamp
 
setTime(long) - Method in class org.apache.openjpa.util.ProxyUtilDate
 
setTimeInMillis(long) - Method in class org.apache.openjpa.util.ProxyGregorianCalendar
 
setTimeout(long) - Method in interface org.apache.openjpa.datacache.DataCachePCDataGenerator.Timed
 
setTimeout(int) - Method in exception org.apache.openjpa.util.LockException
The number of milliseconds to wait for a lock.
setTimestamp(PreparedStatement, int, Timestamp, Calendar, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set the given value as a parameter to the statement.
setTimestamp(Column, Timestamp, Calendar) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the value of the given column in this row.
setTimestamp(Column, Timestamp, Calendar) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setTimestamp(int, Timestamp) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setTimestamp(int, Timestamp, Calendar) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setTimestamp(String, Timestamp) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setTimestamp(String, Timestamp, Calendar) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setTimestamp(int, Timestamp) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setTimestamp(int, Timestamp, Calendar) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setTimeZone(TimeZone) - Method in class org.apache.openjpa.util.ProxyGregorianCalendar
 
settingBooleanField(PersistenceCapable, int, boolean, boolean, int) - Method in interface org.apache.openjpa.enhance.StateManager
Setting state callback.
settingBooleanField(PersistenceCapable, int, boolean, boolean, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
settingBooleanField(PersistenceCapable, int, boolean, boolean, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
settingBooleanField(PersistenceCapable, int, boolean, boolean, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
settingBooleanField(PersistenceCapable, int, boolean, boolean, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
settingByteField(PersistenceCapable, int, byte, byte, int) - Method in interface org.apache.openjpa.enhance.StateManager
Setting state callback.
settingByteField(PersistenceCapable, int, byte, byte, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
settingByteField(PersistenceCapable, int, byte, byte, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
settingByteField(PersistenceCapable, int, byte, byte, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
settingByteField(PersistenceCapable, int, byte, byte, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
settingCharField(PersistenceCapable, int, char, char, int) - Method in interface org.apache.openjpa.enhance.StateManager
Setting state callback.
settingCharField(PersistenceCapable, int, char, char, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
settingCharField(PersistenceCapable, int, char, char, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
settingCharField(PersistenceCapable, int, char, char, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
settingCharField(PersistenceCapable, int, char, char, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
settingDoubleField(PersistenceCapable, int, double, double, int) - Method in interface org.apache.openjpa.enhance.StateManager
Setting state callback.
settingDoubleField(PersistenceCapable, int, double, double, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
settingDoubleField(PersistenceCapable, int, double, double, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
settingDoubleField(PersistenceCapable, int, double, double, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
settingDoubleField(PersistenceCapable, int, double, double, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
settingFloatField(PersistenceCapable, int, float, float, int) - Method in interface org.apache.openjpa.enhance.StateManager
Setting state callback.
settingFloatField(PersistenceCapable, int, float, float, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
settingFloatField(PersistenceCapable, int, float, float, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
settingFloatField(PersistenceCapable, int, float, float, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
settingFloatField(PersistenceCapable, int, float, float, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
settingIntField(PersistenceCapable, int, int, int, int) - Method in interface org.apache.openjpa.enhance.StateManager
Setting state callback.
settingIntField(PersistenceCapable, int, int, int, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
settingIntField(PersistenceCapable, int, int, int, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
settingIntField(PersistenceCapable, int, int, int, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
settingIntField(PersistenceCapable, int, int, int, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
settingLongField(PersistenceCapable, int, long, long, int) - Method in interface org.apache.openjpa.enhance.StateManager
Setting state callback.
settingLongField(PersistenceCapable, int, long, long, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
settingLongField(PersistenceCapable, int, long, long, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
settingLongField(PersistenceCapable, int, long, long, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
settingLongField(PersistenceCapable, int, long, long, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
settingObjectField(PersistenceCapable, int, Object, Object, int) - Method in interface org.apache.openjpa.enhance.StateManager
Setting state callback.
settingObjectField(PersistenceCapable, int, Object, Object, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
settingObjectField(PersistenceCapable, int, Object, Object, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
settingObjectField(PersistenceCapable, int, Object, Object, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
settingObjectField(PersistenceCapable, int, Object, Object, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
settingShortField(PersistenceCapable, int, short, short, int) - Method in interface org.apache.openjpa.enhance.StateManager
Setting state callback.
settingShortField(PersistenceCapable, int, short, short, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
settingShortField(PersistenceCapable, int, short, short, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
settingShortField(PersistenceCapable, int, short, short, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
settingShortField(PersistenceCapable, int, short, short, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
settingStringField(PersistenceCapable, int, String, String, int) - Method in interface org.apache.openjpa.enhance.StateManager
Setting state callback.
settingStringField(PersistenceCapable, int, String, String, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
settingStringField(PersistenceCapable, int, String, String, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
settingStringField(PersistenceCapable, int, String, String, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
settingStringField(PersistenceCapable, int, String, String, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
setTmpClassLoader(boolean) - Method in class org.apache.openjpa.ant.PCEnhancerTask
Set whether or not to use a default class loader for loading the unenhanced classes.
setToken(String) - Method in class org.apache.openjpa.ant.ApplicationIdToolTask
Set the token to separate stringified primary key field values.
setToken(String) - Method in class org.apache.openjpa.enhance.ApplicationIdTool
The token to use to separate stringified primary key field values.
setTool(ReverseMappingTool) - Method in class org.apache.openjpa.jdbc.meta.PropertiesReverseCustomizer
 
setTool(ReverseMappingTool) - Method in interface org.apache.openjpa.jdbc.meta.ReverseCustomizer
Set the reverse mapping tool using this customizer.
setTopic(String) - Method in class org.apache.openjpa.event.JMSRemoteCommitProvider
Sets the JMS Topic name.
setTopicConnectionFactory(String) - Method in class org.apache.openjpa.event.JMSRemoteCommitProvider
Sets the JMS TopicConnectionFactory name.
setTrackChanges(boolean) - Method in class org.apache.openjpa.util.ProxyManagerImpl
Whether proxies produced by this factory will use ChangeTrackers to try to cut down on data store operations at the cost of some extra bookkeeping overhead.
setTrackKeys(boolean) - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
setTrackKeys(boolean) - Method in interface org.apache.openjpa.util.MapChangeTracker
Whether to track keys or values.
setTrackKeys(boolean) - Method in class org.apache.openjpa.util.MapChangeTrackerImpl
 
setTrackParameters(boolean) - Method in class org.apache.openjpa.lib.jdbc.LoggingConnectionDecorator
Whether to track parameters for the purposes of reporting exceptions.
setTransactionIsolation(String) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The transaction isolation level to use at the database level.
setTransactionIsolation(int) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
Set the proper transaction isolation level constant from Connection, or -1 for the default level.
setTransactionIsolation(String) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setTransactionIsolation(int) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setTransactionIsolation(int) - Method in class org.apache.openjpa.lib.jdbc.ConfiguringConnectionDecorator
The transaction isolation level.
setTransactionIsolation(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
setTransactionListenerCallbackMode(int) - Method in interface org.apache.openjpa.kernel.Broker
The callback mode for handling exceptions from transaction event listeners.
setTransactionListenerCallbackMode(int) - Method in class org.apache.openjpa.kernel.BrokerImpl
 
setTransactionListenerCallbackMode(int) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
setTransactionListenerCallbackMode(int) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
setTransactionListenerCallbackMode(int) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
The CallbackModes flags for handling transaction listener exceptions.
setTransactionManagerMethod(String) - Method in class org.apache.openjpa.ee.InvocationManagedRuntime
Set the method to invoke to get the TransactionManager.
setTransactionManagerName(String) - Method in class org.apache.openjpa.ee.JNDIManagedRuntime
Set the location of the TransactionManager in JNDI.
setTransactionMode(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Specifies the behavior of the transaction model.
setTransactionMode(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setTransactionModeManaged(boolean) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Set whether managed transactions are being used.
setTransactionModeManaged(boolean) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setTransactionType(PersistenceUnitTransactionType) - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
 
setTransient(boolean) - Method in class org.apache.openjpa.meta.FieldMetaData
Return whether this is a transient field.
setTransmitPersistedObjectIds(boolean) - Method in class org.apache.openjpa.conf.RemoteCommitProviderValue
The cached decorators.
setTransmitPersistedObjectIds(boolean) - Method in class org.apache.openjpa.event.RemoteCommitEventManager
Whether the oids of added instances will be transmitted.
setType(int) - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSeq
Records the sequence type.
setType(int) - Method in class org.apache.openjpa.jdbc.schema.Column
Set the column's SQL type.
setType(int) - Method in class org.apache.openjpa.jdbc.sql.Join
 
setType(int) - Method in class org.apache.openjpa.kernel.DelegatingSeq
 
setType(int) - Method in interface org.apache.openjpa.kernel.Seq
Set the type of sequence.
setType(int) - Method in class org.apache.openjpa.kernel.TimeSeededSeq
 
setType(int) - Method in class org.apache.openjpa.kernel.UUIDHexSeq
 
setType(int) - Method in class org.apache.openjpa.kernel.UUIDStringSeq
 
setType(Class) - Method in class org.apache.openjpa.meta.FieldMetaData
 
setType(int) - Method in class org.apache.openjpa.meta.SequenceMetaData
The sequence type.
setType(Class) - Method in interface org.apache.openjpa.meta.ValueMetaData
The value class.
setType(Class) - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
setTypeAlias(String) - Method in class org.apache.openjpa.meta.ClassMetaData
Sets the alias for the described type.
setTypeCode(int) - Method in class org.apache.openjpa.meta.FieldMetaData
 
setTypeCode(int) - Method in interface org.apache.openjpa.meta.ValueMetaData
The type code of the value class.
setTypeCode(int) - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
setTyped(PreparedStatement, int, Object, Column, int, JDBCStore) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set a column value into a prepared statement.
setTypeMap(String) - Method in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
Set the SQL type map overrides.
setTypeMap(Properties) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Map of JDBC-name to Java-type-name entries that allows customization of reverse mapping columns to field types.
setTypeMap(Map) - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
setTypeName(String) - Method in class org.apache.openjpa.jdbc.schema.Column
The database-specific SQL type of this column.
setTypeOverride(Class) - Method in class org.apache.openjpa.meta.FieldMetaData
 
setTypeOverride(Class) - Method in interface org.apache.openjpa.meta.ValueMetaData
User-supplied type overriding assumed type based on field.
setTypeOverride(Class) - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
setTypes(Set) - Method in class org.apache.openjpa.meta.AbstractMetaDataFactory
Set of persistent type names supplied by user.
setTypes(String) - Method in class org.apache.openjpa.meta.AbstractMetaDataFactory
Set of semicolon-separated persistent type names supplied by user via auto-configuration.
setUnicodeStream(int, InputStream, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setUnicodeStream(int, InputStream, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setUnique(Unique) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Raw unique constraint information.
setUnique(boolean) - Method in class org.apache.openjpa.jdbc.schema.Index
Set whether this is a UNIQUE index.
setUnique(boolean) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
setUnique(boolean) - Method in interface org.apache.openjpa.kernel.QueryContext
Specify that the query will return only 1 result, rather than a collection.
setUnique(boolean) - Method in class org.apache.openjpa.kernel.QueryImpl
 
setUnknown(PreparedStatement, int, Object, Column) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Set a completely unknown parameter into a prepared statement.
setup() - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
Setup transient state used by this factory based on the current configuration, which will subsequently be locked down.
setUpdatable(int, boolean) - Method in class org.apache.openjpa.jdbc.schema.ColumnIO
Whether the column at the given index is updatable in this context.
setUpdateAction(int) - Method in class org.apache.openjpa.jdbc.schema.ForeignKey
Set the update action for the key.
setUpdateManager(String) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The UpdateManager to use for managing SQL updates.
setUpdateManager(UpdateManager) - Method in interface org.apache.openjpa.jdbc.conf.JDBCConfiguration
The UpdateManager for runtime data store interaction.
setUpdateManager(String) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setUpdateManager(UpdateManager) - Method in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
setUpdateStrategy(int) - Method in class org.apache.openjpa.meta.FieldMetaData
Set the update strategy.
setURL(int, URL) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setURL(String, URL) - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
setURL(int, URL) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
setURLs(Collection) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Set of URLs of metadata files or jars supplied by user.
setURLs(String) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
Set of semicolon-separated URLs of metadata files or jars supplied by user via auto-configuration.
setUseAliases(boolean) - Method in class org.apache.openjpa.jdbc.kernel.ClassTableJDBCSeq
Whether to use type alises for primary key values in place of class names.
setUseBuiltinIdentityClass(boolean) - Method in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
Set whether to use single field identity where possible.
setUseBuiltinIdentityClass(boolean) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Whether to use built in identity classes when possible.
setUseClassCriteria(boolean) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
setUseClassCriteria(boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
setUseClassCriteria(boolean) - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
Whether to use class criteria when joining to related type.
setUseClassCriteria(boolean) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
setUseClassCriteria(boolean) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingInfo
Whether to use class criteria when joining to related type.
setUseDataStoreIdentity(boolean) - Method in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
Set whether to use datastore identity by default.
setUseDataStoreIdentity(boolean) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Whether to use datastore identity when possible.
setUseForeignKeyName(boolean) - Method in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
Set whether to use foreign key names to name relations.
setUseForeignKeyName(boolean) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Set whether the foreign key name will be used to generate relation names.
setUseParentClassloader(boolean) - Method in class org.apache.openjpa.lib.ant.AbstractTask
Whether we want to delegate to the parent ClassLoader for resolveing classes.
setUsePCRegistry(boolean) - Method in class org.apache.openjpa.meta.AbstractMetaDataDefaults
Whether to attempt to use the information from registered classes to populate metadata defaults.
setUseSchemaName(boolean) - Method in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
Set whether to use the schema name when naming the classes.
setUseSchemaName(boolean) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Set whether the schema name will be included in the generated class name for each table.
setUsesImplData(Boolean) - Method in class org.apache.openjpa.meta.FieldMetaData
Whether this field uses impl data in conjunction with standard field data when acting on a OpenJPAStateManager.
setUsesIntermediate(boolean) - Method in class org.apache.openjpa.meta.FieldMetaData
Whether this field uses intermediate data when loading/storing information through a OpenJPAStateManager.
setValid(boolean) - Method in interface org.apache.openjpa.jdbc.sql.Row
Whether this row has information set on it.
setValid(boolean) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
setValidate(int) - Method in class org.apache.openjpa.meta.MetaDataRepository
The metadata validation level.
setValidate(int, boolean) - Method in class org.apache.openjpa.meta.MetaDataRepository
The metadata validation level.
setValidateFalseReturnsHollow(boolean) - Method in class org.apache.openjpa.conf.Compatibility
Whether to return hollow instances to broker lookups with a validate parameter of false.
setValidateTrueChecksStore(boolean) - Method in class org.apache.openjpa.conf.Compatibility
Whether to check the datastore for the existence of a nontransactional cached object in broker lookups with a validate parameter of true.
setValidating(boolean) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Whether this is a validating parser.
setValue(Object) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
The discriminator value.
setValue(String) - Method in class org.apache.openjpa.jdbc.meta.DiscriminatorMappingInfo
Raw discriminator value string.
setValue(Object) - Method in interface org.apache.openjpa.kernel.exps.Literal
The value of this literal.
setValue(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap.Entry
 
setValueIndex(Index) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
setValueIndex(Index) - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
Index on this value's columns, or null if none.
setValueIndex(Index) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
setValueMappedBy(String) - Method in class org.apache.openjpa.meta.FieldMetaData
 
setValueMappedBy(String) - Method in interface org.apache.openjpa.meta.ValueMetaData
The field that this value shares a mapping with.
setValueMappedBy(String) - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
setValueSequenceName(String) - Method in class org.apache.openjpa.meta.FieldMetaData
The value sequence name, or null for none.
setValueStrategy(int) - Method in class org.apache.openjpa.meta.FieldMetaData
The strategy to use for insert value generation.
setValueUnique(Unique) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
setValueUnique(Unique) - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
Unique constraint on this value's columns, or null if none.
setValueUnique(Unique) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
setVariable(String) - Method in interface org.apache.openjpa.jdbc.sql.Joins
Set the variable name being traversed into with the next join.
setVariable(String) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl.SelectResult
 
setVariable(String) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
setVersion(Object) - Method in class org.apache.openjpa.datacache.DataCachePCDataImpl
 
setVersion(Version) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractVersionStrategy
 
setVersion(Version) - Method in class org.apache.openjpa.jdbc.meta.strats.NoneVersionStrategy
 
setVersion(Version) - Method in class org.apache.openjpa.jdbc.meta.Version
 
setVersion(Version) - Method in interface org.apache.openjpa.jdbc.meta.VersionStrategy
Set the version that uses this strategy.
setVersion(Object) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
setVersion(Object) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
setVersion(Object) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
setVersion(Object) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Set the version indicator for this instance, as loaded from the data store.
setVersion(Object) - Method in interface org.apache.openjpa.kernel.PCData
Sets the current version object that this data was loaded from.
setVersion(Object) - Method in class org.apache.openjpa.kernel.PCDataImpl
 
setVersion(Object) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
setVersion(boolean) - Method in class org.apache.openjpa.meta.FieldMetaData
Whether this field holds optimistic version information.
setVersion(Long) - Method in class org.apache.openjpa.xmlstore.ObjectData
Set the version number of the object.
setVersionCheckOnReadLock(boolean) - Method in class org.apache.openjpa.kernel.VersionLockManager
Whether or not we should force a version check at commit time when a read lock is requested in order to verify read consistency.
setVersionColumnName(String) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default base name for version identity columns, or null to the mapping's built-in name.
setVersionStrategy(String) - Method in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
Default version strategy for base class mappings.
setVersionStrategy(String) - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
Default version strategy alias.
setVersionStrategy(String) - Method in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Default version strategy for base class mappings.
setVersionUpdateOnWriteLock(boolean) - Method in class org.apache.openjpa.kernel.VersionLockManager
Whether or not we should force an update to the version at commit time when a write lock is requested.
setWarningAction(String) - Method in class org.apache.openjpa.lib.jdbc.LoggingConnectionDecorator
What to do with SQL warnings.
setWarningHandler(LoggingConnectionDecorator.SQLWarningHandler) - Method in class org.apache.openjpa.lib.jdbc.LoggingConnectionDecorator
What to do with SQL warnings.
setWrapIndent(String) - Method in class org.apache.openjpa.lib.jdbc.SQLFormatter
 
setWriteLockLevel(String) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The default write lock level to use during non-optimistic transactions.
setWriteLockLevel(int) - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
The numeric write lock level.
setWriteLockLevel(String) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setWriteLockLevel(int) - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
setWriteLockLevel(int) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
setWriteLockLevel(int) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
The lock level to use for locking dirtied objects.
setWriteLockLevel(int) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
setWriteLockMode(LockModeType) - Method in interface org.apache.openjpa.persistence.FetchPlan
The lock level to use for locking dirtied objects.
setWriteLockMode(LockModeType) - Method in class org.apache.openjpa.persistence.FetchPlanImpl
 
setWriter(Writer) - Method in class org.apache.openjpa.enhance.ApplicationIdTool
The writer to write source to, or null to write to default file.
setWriter(Writer) - Method in class org.apache.openjpa.jdbc.schema.SchemaTool
The stream to write to for the creation of SQL scripts.
setWriter(Writer) - Method in class org.apache.openjpa.meta.MetaDataTool
The writer to generate metadata to.
setXMLParser(XMLPersistenceMetaDataParser) - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
Set the metadata parser.
setYear(int) - Method in class org.apache.openjpa.util.ProxySQLDate
 
setYear(int) - Method in class org.apache.openjpa.util.ProxyTime
 
setYear(int) - Method in class org.apache.openjpa.util.ProxyTimestamp
 
setYear(int) - Method in class org.apache.openjpa.util.ProxyUtilDate
 
SHORT - Static variable in class org.apache.openjpa.meta.JavaTypes
 
SHORT_OBJ - Static variable in class org.apache.openjpa.meta.JavaTypes
 
shorten(String, int) - Static method in class org.apache.openjpa.jdbc.sql.DBDictionary
Shorten the specified name to the specified target name.
ShortId - Class in org.apache.openjpa.util
OpenJPAId subclass appropriate for short fields.
ShortId(Class, Short) - Constructor for class org.apache.openjpa.util.ShortId
 
ShortId(Class, String) - Constructor for class org.apache.openjpa.util.ShortId
 
ShortId(Class, short) - Constructor for class org.apache.openjpa.util.ShortId
 
ShortId(Class, short, boolean) - Constructor for class org.apache.openjpa.util.ShortId
 
shutdownOnClose - Variable in class org.apache.openjpa.jdbc.sql.DerbyDictionary
If true, we will shutdown the embedded database when closing the DataSource.
signal() - Method in interface org.apache.openjpa.lib.util.concurrent.Condition
Wakes up one waiting thread.
signal(WaitQueue.QueuedSync) - Method in class org.apache.openjpa.lib.util.concurrent.WaitQueue.WaitNode
 
signalAll() - Method in interface org.apache.openjpa.lib.util.concurrent.Condition
Wakes up all waiting threads.
SimpleDriverDataSource - Class in org.apache.openjpa.jdbc.schema
Non-pooling driver data source.
SimpleDriverDataSource() - Constructor for class org.apache.openjpa.jdbc.schema.SimpleDriverDataSource
 
SimpleNode - Class in org.apache.openjpa.kernel.jpql
Base node implementation for all JPQL nodes.
SimpleRegex - Class in org.apache.openjpa.lib.util
Allows for simple regex style testing of strings.
SimpleRegex(String, boolean) - Constructor for class org.apache.openjpa.lib.util.SimpleRegex
 
SimpleResultList - Class in org.apache.openjpa.lib.rop
An almost stateless ResultList designed for use with result object providers backed by efficient random-access data structures, such as the ListResultObjectProvider.
SimpleResultList(ResultObjectProvider) - Constructor for class org.apache.openjpa.lib.rop.SimpleResultList
 
simulateLocking - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
SingleJVMRemoteCommitProvider - Class in org.apache.openjpa.event
Single-JVM-only implementation of RemoteCommitProvider that listens for object modifications and propagates those changes to other SingleJVMRemoteCommitProviders in the same JVM.
SingleJVMRemoteCommitProvider() - Constructor for class org.apache.openjpa.event.SingleJVMRemoteCommitProvider
 
size() - Method in class org.apache.openjpa.datacache.QueryCacheStoreQuery.CachedList
 
size(Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
size() - Method in class org.apache.openjpa.jdbc.kernel.GenericResultObjectProvider
 
size() - Method in class org.apache.openjpa.jdbc.kernel.SelectResultObjectProvider
 
size() - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
size() - Method in interface org.apache.openjpa.jdbc.sql.Result
Return the number of rows in this result.
size() - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
size - Variable in class org.apache.openjpa.jdbc.sql.Sized
 
size() - Method in class org.apache.openjpa.kernel.AbstractPCResultObjectProvider
Override if desired.
size() - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
size(Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return an expression representing the given condition.
size(Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
size() - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
size() - Method in class org.apache.openjpa.lib.rop.LazyForwardResultList
 
size() - Method in class org.apache.openjpa.lib.rop.ListResultList
 
size() - Method in class org.apache.openjpa.lib.rop.ListResultObjectProvider
 
size() - Method in class org.apache.openjpa.lib.rop.MergedResultObjectProvider
 
size() - Method in class org.apache.openjpa.lib.rop.RandomAccessResultList
 
size() - Method in class org.apache.openjpa.lib.rop.RangeResultObjectProvider
 
size() - Method in interface org.apache.openjpa.lib.rop.ResultObjectProvider
Return the number of items in the input, or Integer.MAX_VALUE if the size in unknown.
size() - Method in class org.apache.openjpa.lib.rop.SimpleResultList
 
size() - Method in class org.apache.openjpa.lib.rop.WindowResultList
 
size() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
Returns the number of key-value mappings in this map.
size() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashSet
 
size() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentLinkedQueue
Returns the number of elements in this queue.
size() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
Returns the number of key-value mappings in this Map.
size() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashSet
 
size() - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
size() - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArraySet
Returns the number of elements in this set.
size() - Method in class org.apache.openjpa.lib.util.MultiClassLoader
Return the number of internal class loaders.
size() - Method in class org.apache.openjpa.lib.util.ReferenceHashSet
 
size() - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
size() - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
size() - Method in class org.apache.openjpa.util.CacheMap
 
SIZE_LAST - Static variable in interface org.apache.openjpa.jdbc.kernel.LRSSizes
Mode for using ResultSet.last() to calcualte the size of large result sets.
SIZE_QUERY - Static variable in interface org.apache.openjpa.jdbc.kernel.LRSSizes
Mode for using a query to calculate the size of large result sets.
SIZE_UNKNOWN - Static variable in interface org.apache.openjpa.jdbc.kernel.LRSSizes
Mode for returning Integer.MAX_VALUE for the size of large result sets.
Sized - Class in org.apache.openjpa.jdbc.sql
A sized value.
Sized(Object, int) - Constructor for class org.apache.openjpa.jdbc.sql.Sized
 
SizedMap - Interface in org.apache.openjpa.lib.util
A Map type that maintains a maximum size, automatically removing entries when the maximum is exceeded.
skip(long) - Method in class org.apache.openjpa.lib.xml.DocTypeReader
 
skipEnhance(BCMethod) - Method in interface org.apache.openjpa.enhance.PCEnhancer.AuxiliaryEnhancer
 
sleep(long) - Method in class org.apache.openjpa.lib.util.concurrent.TimeUnit
Performs a Thread.sleep using this unit.
sm - Variable in class org.apache.openjpa.jdbc.kernel.ConnectionInfo
 
smallintTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
SOFT - Static variable in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashSet
Soft reference marker.
SOFT - Static variable in class org.apache.openjpa.lib.util.ReferenceHashSet
Soft reference marker.
SOFT - Static variable in interface org.apache.openjpa.lib.util.ReferenceMap
 
softMap - Variable in class org.apache.openjpa.util.CacheMap
The map for expired references.
softMapOverflowRemoved(Object, Object) - Method in class org.apache.openjpa.util.CacheMap
Called from SizedMap.overflowRemoved(java.lang.Object, java.lang.Object) in the soft map.
softMapValueExpired(Object) - Method in class org.apache.openjpa.util.CacheMap
Called when a value expires from the soft map.
SoftRandomAccessResultList - Class in org.apache.openjpa.lib.rop
Specialization of the RandomAccessResultList that only maintains soft references to instantiated objects.
SoftRandomAccessResultList(ResultObjectProvider) - Constructor for class org.apache.openjpa.lib.rop.SoftRandomAccessResultList
 
SourceTracker - Interface in org.apache.openjpa.lib.meta
Interface that can optionally be implemented by metadata to include the source file from which the metadata was originally parsed.
SourceTrackers - Class in org.apache.openjpa.lib.meta
Utility class for performing common operations on SourceTrackers.
SourceTrackers() - Constructor for class org.apache.openjpa.lib.meta.SourceTrackers
 
SPEC_JPA - Static variable in class org.apache.openjpa.persistence.PersistenceProductDerivation
 
splitExpressions(String, char, int) - Static method in class org.apache.openjpa.kernel.Filters
Split the given expression list into distinct expressions.
sql - Variable in class org.apache.openjpa.jdbc.sql.Raw
 
SQL_ARRAY - Static variable in class org.apache.openjpa.jdbc.meta.JavaSQLTypes
 
SQL_DATE - Static variable in class org.apache.openjpa.jdbc.meta.JavaSQLTypes
 
SQL_OBJECT - Static variable in class org.apache.openjpa.jdbc.meta.JavaSQLTypes
 
SQLBuffer - Class in org.apache.openjpa.jdbc.sql
Buffer for SQL statements that can be used to create java.sql.PreparedStatements.
SQLBuffer(DBDictionary) - Constructor for class org.apache.openjpa.jdbc.sql.SQLBuffer
Default constructor.
SQLBuffer(SQLBuffer) - Constructor for class org.apache.openjpa.jdbc.sql.SQLBuffer
Copy constructor.
SQLEmbed - Class in org.apache.openjpa.jdbc.kernel.exps
Simple listener which embeds its SQL argument into the query.
SQLEmbed() - Constructor for class org.apache.openjpa.jdbc.kernel.exps.SQLEmbed
 
sqlEquals(String) - Method in class org.apache.openjpa.jdbc.sql.SQLBuffer
Compare internal SQL without resolving subselects or stringifying parameters.
SQLExceptions - Class in org.apache.openjpa.jdbc.sql
Helper class for converting a SQLException into the appropriate OpenJPA type.
SQLExceptions() - Constructor for class org.apache.openjpa.jdbc.sql.SQLExceptions
 
SQLExpression - Class in org.apache.openjpa.jdbc.kernel.exps
Deprecated. Use SQLEmbed directly
SQLExpression() - Constructor for class org.apache.openjpa.jdbc.kernel.exps.SQLExpression
Deprecated.  
SQLFactory - Interface in org.apache.openjpa.jdbc.sql
Factory for SQL constructs.
SQLFactoryImpl - Class in org.apache.openjpa.jdbc.sql
Default factory for SQL abstraction constructs.
SQLFactoryImpl() - Constructor for class org.apache.openjpa.jdbc.sql.SQLFactoryImpl
 
sqlFactoryPlugin - Variable in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
sqlFile - Variable in class org.apache.openjpa.jdbc.ant.MappingToolTask
 
SQLFormatter - Class in org.apache.openjpa.lib.jdbc
Converts single-line SQL strings into nicely-formatted multi-line, indented statements.
SQLFormatter() - Constructor for class org.apache.openjpa.lib.jdbc.SQLFormatter
 
SQLServerDictionary - Class in org.apache.openjpa.jdbc.sql
Dictionary for MS SQLServer.
SQLServerDictionary() - Constructor for class org.apache.openjpa.jdbc.sql.SQLServerDictionary
 
SQLStoreQuery - Class in org.apache.openjpa.jdbc.kernel
A SQL query.
SQLStoreQuery(JDBCStore) - Constructor for class org.apache.openjpa.jdbc.kernel.SQLStoreQuery
Construct a query managed by the given context.
SQLValue - Class in org.apache.openjpa.jdbc.kernel.exps
Deprecated. Use SQLEmbed directly
SQLValue() - Constructor for class org.apache.openjpa.jdbc.kernel.exps.SQLValue
Deprecated.  
sqlWriter - Variable in class org.apache.openjpa.jdbc.meta.MappingTool.Flags
 
sqrt(Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
sqrt(Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return the square root of the given value.
sqrt(Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
SRC_ANNOTATIONS - Static variable in interface org.apache.openjpa.lib.meta.SourceTracker
 
SRC_OTHER - Static variable in interface org.apache.openjpa.lib.meta.SourceTracker
 
SRC_XML - Static variable in interface org.apache.openjpa.lib.meta.SourceTracker
 
start - Variable in class org.apache.openjpa.kernel.StoreQuery.Range
 
startCascade(Object, Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Lazily parse cascades.
startCDATA() - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
 
startClass(String, Attributes) - Method in class org.apache.openjpa.lib.meta.CFMetaDataParser
Start a class.
startClass(String, Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
startClassElement(String, Attributes) - Method in class org.apache.openjpa.lib.meta.CFMetaDataParser
Override this method marking the start of an element within a declared class.
startClassElement(String, Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
startClassMapping(ClassMetaData, boolean, Attributes) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingParser
 
startClassMapping(ClassMetaData, boolean, Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Implement to add mapping attributes to class.
startClassMappingElement(String, Attributes) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingParser
 
startClassMappingElement(String, Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Implement to parse a mapping element within a class.
startConfiguration() - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
startConfiguration() - Method in class org.apache.openjpa.datacache.AbstractQueryCache
 
startConfiguration() - Method in class org.apache.openjpa.ee.AutomaticManagedRuntime
 
startConfiguration() - Method in class org.apache.openjpa.ee.InvocationManagedRuntime
 
startConfiguration() - Method in class org.apache.openjpa.ee.WASManagedRuntime
StartConfiguration stub.
startConfiguration() - Method in class org.apache.openjpa.event.AbstractRemoteCommitProvider
 
startConfiguration() - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSavepointManager
 
startConfiguration() - Method in class org.apache.openjpa.jdbc.kernel.AbstractUpdateManager
 
startConfiguration() - Method in class org.apache.openjpa.jdbc.kernel.NativeJDBCSeq
 
startConfiguration() - Method in class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
 
startConfiguration() - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
startConfiguration() - Method in class org.apache.openjpa.jdbc.schema.DynamicSchemaFactory
 
startConfiguration() - Method in class org.apache.openjpa.jdbc.schema.FileSchemaFactory
 
startConfiguration() - Method in class org.apache.openjpa.jdbc.schema.LazySchemaFactory
 
startConfiguration() - Method in class org.apache.openjpa.jdbc.schema.TableSchemaFactory
 
startConfiguration() - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
 
startConfiguration() - Method in class org.apache.openjpa.jdbc.sql.SQLFactoryImpl
 
startConfiguration() - Method in class org.apache.openjpa.kernel.InverseManager
 
startConfiguration() - Method in interface org.apache.openjpa.lib.conf.Configurable
Invoked before bean property configuration is begun on this object.
startConfiguration() - Method in class org.apache.openjpa.meta.MetaDataRepository
 
startConfiguration() - Method in class org.apache.openjpa.persistence.PersistenceMetaDataFactory
 
startConfiguration() - Method in class org.apache.openjpa.util.ProxyManagerImpl
 
startDataRequest(Object) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
startDataRequest(Object) - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
startDataRequest(Object) - Method in interface org.apache.openjpa.jdbc.sql.Result
Informs this receiver about the application element for which a subsequent data request will be made.
startDTD(String, String, String) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
 
startElement(String, Attributes) - Method in class org.apache.openjpa.jdbc.schema.XMLSchemaParser
 
startElement(String, Attributes) - Method in class org.apache.openjpa.lib.meta.CFMetaDataParser
 
startElement(String, String, String, Attributes) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
 
startElement(String, Attributes) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
Override this method marking the start of some element.
startElement(String) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
Start an element with the current attribute settings.
startEmbeddedId(Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Parse embedded-id.
startEntity(String) - Method in class org.apache.openjpa.lib.meta.XMLMetaDataParser
 
startFieldMapping(FieldMetaData, Attributes) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingParser
Extend to clear annotation mapping info.
startFieldMapping(FieldMetaData, Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Implement to add field mapping data.
startGeneratedValue(Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Parse generated-value.
startId(Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Parse id.
startIdClass(Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Parse id-class.
startLob(Attributes) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingParser
 
startLob(Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Parse lob.
startNamedNativeQuery(Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Parse native-named-query.
startNamedQuery(Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Parse named-query.
startPackage(String, Attributes) - Method in class org.apache.openjpa.lib.meta.CFMetaDataParser
Start a package.
startPackageElement(String, Attributes) - Method in class org.apache.openjpa.lib.meta.CFMetaDataParser
Override this method marking the start of an element within a declared package.
startQueryHint(Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Parse query-hint.
startQueryString(Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
startSequenceGenerator(Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Parse sequence-generator.
startsWith(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
startsWith(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return whether the first string starts with the second.
startsWith(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
startSystemElement(String, Attributes) - Method in class org.apache.openjpa.lib.meta.CFMetaDataParser
Override this method marking the start of an element outside of any package or class.
startSystemElement(String, Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
 
startSystemMappingElement(String, Attributes) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingParser
 
startSystemMappingElement(String, Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Implement to parse a mapping element outside of any class.
startTracking() - Method in class org.apache.openjpa.util.AbstractChangeTracker
 
startTracking() - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
startTracking() - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
startTracking() - Method in interface org.apache.openjpa.util.ChangeTracker
Reset the state of the change tracker, and turn change tracking back on if it has been disabled.
startVersion(Attributes) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Parse version.
StateComparisonVersionStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Uses a state image to determine whether concurrency violations take place.
StateComparisonVersionStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy
 
StateComparisonVersionStrategy.CustomUpdate - Class in org.apache.openjpa.jdbc.meta.strats
Row implementation we use to pass to versionable mappings so they can set up the where conditions we need to add to update statements.
StateManager - Interface in org.apache.openjpa.enhance
Internal state manager for managed instances.
StateManagerImpl - Class in org.apache.openjpa.kernel
Implementation of the OpenJPAStateManager interface for use with this runtime.
StateManagerImpl(Object, ClassMetaData, BrokerImpl) - Constructor for class org.apache.openjpa.kernel.StateManagerImpl
Constructor; supply id, type metadata, and owning persistence manager.
STDERR - Static variable in class org.apache.openjpa.lib.log.LogFactoryImpl
 
STDOUT - Static variable in class org.apache.openjpa.lib.log.LogFactoryImpl
 
stop() - Method in class org.apache.openjpa.datacache.DataCacheScheduler
Stop the associated thread if there and stop the current runnable.
stopTracking() - Method in class org.apache.openjpa.util.AbstractChangeTracker
 
stopTracking() - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
stopTracking() - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
stopTracking() - Method in interface org.apache.openjpa.util.ChangeTracker
Tell the tracker to stop tracking changes for its container.
storageLimitationsFatal - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
storageWarning(Object, Object) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Warn that a particular value could not be stored precisely.
store(OpenJPAStateManager) - Method in class org.apache.openjpa.datacache.DataCachePCDataImpl
 
store(OpenJPAStateManager, BitSet) - Method in class org.apache.openjpa.datacache.DataCachePCDataImpl
 
store - Variable in class org.apache.openjpa.jdbc.kernel.exps.ExpContext
Store.
store(ClassMetaData[], QueryMetaData[], SequenceMetaData[], int, Map) - Method in class org.apache.openjpa.jdbc.meta.MetaDataPlusMappingFactory
 
store(int, Object) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
store(int, Object) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
store(int, Object) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
store(int, Object) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Set the value of the field with the given index as from the external object value.
store(OpenJPAStateManager) - Method in interface org.apache.openjpa.kernel.PCData
Store all loaded fields of the state manager.
store(OpenJPAStateManager, BitSet) - Method in interface org.apache.openjpa.kernel.PCData
Store the given fields from the state manager.
store(OpenJPAStateManager) - Method in class org.apache.openjpa.kernel.PCDataImpl
 
store(OpenJPAStateManager, BitSet) - Method in class org.apache.openjpa.kernel.PCDataImpl
 
store(int, Object) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
store(OutputStream, String) - Method in class org.apache.openjpa.lib.util.FormatPreservingProperties
 
store(ClassMetaData[], QueryMetaData[], SequenceMetaData[], int, Map) - Method in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
 
store - Variable in class org.apache.openjpa.meta.AbstractMetaDataFactory
 
store(ClassMetaData[], QueryMetaData[], SequenceMetaData[], int, Map) - Method in class org.apache.openjpa.meta.AbstractMetaDataFactory
 
store(ClassMetaData[], QueryMetaData[], SequenceMetaData[], int, Map) - Method in class org.apache.openjpa.meta.DelegatingMetaDataFactory
 
store(ClassMetaData[], QueryMetaData[], SequenceMetaData[], int, Map) - Method in interface org.apache.openjpa.meta.MetaDataFactory
Store the given metadata.
store(ClassMetaData[], QueryMetaData[], SequenceMetaData[], int, Map) - Method in class org.apache.openjpa.meta.NoneMetaDataFactory
 
STORE - Static variable in interface org.apache.openjpa.util.ExceptionInfo
 
store(OpenJPAStateManager) - Method in class org.apache.openjpa.xmlstore.ObjectData
Store the data and version information for this object from the given state manager.
store(ClassMetaData, Collection) - Method in class org.apache.openjpa.xmlstore.XMLFileHandler
Stores all instances in datas into the appropriate file, as dictated by meta.
STORE_DEFAULT - Static variable in interface org.apache.openjpa.meta.MetaDataFactory
 
STORE_PER_CLASS - Static variable in interface org.apache.openjpa.meta.MetaDataFactory
 
STORE_VERBOSE - Static variable in interface org.apache.openjpa.meta.MetaDataFactory
 
storeBoolean(int, boolean) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
storeBoolean(int, boolean) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
storeBoolean(int, boolean) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
storeBoolean(int, boolean) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Set the given external value back into the given field.
storeBoolean(int, boolean) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
storeBooleanField(int, boolean) - Method in interface org.apache.openjpa.enhance.FieldConsumer
Set the value of the given field.
storeBooleanField(int, boolean) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
storeBooleanField(int, boolean) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
storeByte(int, byte) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
storeByte(int, byte) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
storeByte(int, byte) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
storeByte(int, byte) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Set the given external value back into the given field.
storeByte(int, byte) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
storeByteField(int, byte) - Method in interface org.apache.openjpa.enhance.FieldConsumer
Set the value of the given field.
storeByteField(int, byte) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
storeByteField(int, byte) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
StoreCache - Interface in org.apache.openjpa.persistence
Represents the L2 cache over the data store.
StoreCacheImpl - Class in org.apache.openjpa.persistence
Implements the L2 cache over the data store via delegation to DataCache.
StoreCacheImpl(EntityManagerFactoryImpl, DataCache) - Constructor for class org.apache.openjpa.persistence.StoreCacheImpl
Constructor; supply delegate.
storeChar(int, char) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
storeChar(int, char) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
storeChar(int, char) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
storeChar(int, char) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Set the given external value back into the given field.
storeChar(int, char) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
storeCharField(int, char) - Method in interface org.apache.openjpa.enhance.FieldConsumer
Set the value of the given field.
storeCharField(int, char) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
storeCharField(int, char) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
storeCharsAsNumbers - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
StoreCollectionFieldStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Base class for strategies that are stored as a collection, even if their field value is something else.
StoreCollectionFieldStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.StoreCollectionFieldStrategy
 
StoreContext - Interface in org.apache.openjpa.kernel
Represents a set of managed objects and their environment.
storeData - Variable in class org.apache.openjpa.kernel.QueryImpl.Compilation
 
storeDouble(int, double) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
storeDouble(int, double) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
storeDouble(int, double) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
storeDouble(int, double) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Set the given external value back into the given field.
storeDouble(int, double) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
storeDoubleField(int, double) - Method in interface org.apache.openjpa.enhance.FieldConsumer
Set the value of the given field.
storeDoubleField(int, double) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
storeDoubleField(int, double) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
StoreException - Exception in org.apache.openjpa.util
Base exception for data store errors.
StoreException(String) - Constructor for exception org.apache.openjpa.util.StoreException
 
StoreException(Localizer.Message) - Constructor for exception org.apache.openjpa.util.StoreException
 
StoreException(Throwable) - Constructor for exception org.apache.openjpa.util.StoreException
 
StoreFacadeTypeRegistry - Class in org.apache.openjpa.util
Repository of store-specific facade classes.
StoreFacadeTypeRegistry() - Constructor for class org.apache.openjpa.util.StoreFacadeTypeRegistry
 
storeField(int, Object) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
storeField(int, Object) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
storeField(OpenJPAStateManager, FieldMetaData, Object, Object) - Method in class org.apache.openjpa.kernel.InverseManager
Store a given value at the given field.
storeField(int, Object) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
storeField(int, Object) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Set the value of the field with the given index as an object.
storeField(OpenJPAStateManager, FieldMetaData) - Method in class org.apache.openjpa.kernel.PCDataImpl
Store field-level information from the given state manager.
storeField(int, Object) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
storeFloat(int, float) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
storeFloat(int, float) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
storeFloat(int, float) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
storeFloat(int, float) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Set the given external value back into the given field.
storeFloat(int, float) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
storeFloatField(int, float) - Method in interface org.apache.openjpa.enhance.FieldConsumer
Set the value of the given field.
storeFloatField(int, float) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
storeFloatField(int, float) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
storeImplData(OpenJPAStateManager) - Method in class org.apache.openjpa.kernel.PCDataImpl
Store impl data from the given state manager.
storeImplData(OpenJPAStateManager, FieldMetaData, boolean) - Method in class org.apache.openjpa.kernel.PCDataImpl
Store impl data for the given field.
storeInt(int, int) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
storeInt(int, int) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
storeInt(int, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
storeInt(int, int) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Set the given external value back into the given field.
storeInt(int, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
storeIntermediate(OpenJPAStateManager, FieldMetaData) - Method in class org.apache.openjpa.kernel.PCDataImpl
Store the intermediate field value for the given field.
storeIntField(int, int) - Method in interface org.apache.openjpa.enhance.FieldConsumer
Set the value of the given field.
storeIntField(int, int) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
storeIntField(int, int) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
storeLargeNumbersAsStrings - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
StoreListener - Interface in org.apache.openjpa.event
Listener for when persistent instances are stored to the database.
storeLong(int, long) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
storeLong(int, long) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
storeLong(int, long) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
storeLong(int, long) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Set the given external value back into the given field.
storeLong(int, long) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
storeLongField(int, long) - Method in interface org.apache.openjpa.enhance.FieldConsumer
Set the value of the given field.
storeLongField(int, long) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
storeLongField(int, long) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
StoreManager - Interface in org.apache.openjpa.kernel
Interface to be implemented by data store mechanisms to interact with this runtime.
storeNull(OpenJPAStateManager, FieldMetaData, Object) - Method in class org.apache.openjpa.kernel.InverseManager
Store null value at the given field.
storeObject(int, Object) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
storeObject(int, Object) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
storeObject(int, Object) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
storeObject(int, Object) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Set the given external value back into the given field.
storeObject(int, Object) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
storeObjectField(int, Object) - Method in interface org.apache.openjpa.enhance.FieldConsumer
Set the value of the given field.
storeObjectField(int, Object) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
storeObjectField(int, Object) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
StoreQuery - Interface in org.apache.openjpa.kernel
Component that executes queries against the datastore.
StoreQuery.Executor - Interface in org.apache.openjpa.kernel
An executor provides a uniform interface to the mechanism for executing either an in-memory or datastore query.
StoreQuery.Range - Class in org.apache.openjpa.kernel
A query result range.
StoreQuery.Range() - Constructor for class org.apache.openjpa.kernel.StoreQuery.Range
 
StoreQuery.Range(long, long) - Constructor for class org.apache.openjpa.kernel.StoreQuery.Range
 
storeSchema(SchemaGroup) - Method in class org.apache.openjpa.jdbc.schema.DynamicSchemaFactory
 
storeSchema(SchemaGroup) - Method in class org.apache.openjpa.jdbc.schema.FileSchemaFactory
 
storeSchema(SchemaGroup) - Method in class org.apache.openjpa.jdbc.schema.LazySchemaFactory
 
storeSchema(SchemaGroup) - Method in interface org.apache.openjpa.jdbc.schema.SchemaFactory
Record the schema group after changes may have been made.
storeSchema(SchemaGroup) - Method in class org.apache.openjpa.jdbc.schema.TableSchemaFactory
 
storeShort(int, short) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
storeShort(int, short) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
storeShort(int, short) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
storeShort(int, short) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Set the given external value back into the given field.
storeShort(int, short) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
storeShortField(int, short) - Method in interface org.apache.openjpa.enhance.FieldConsumer
Set the value of the given field.
storeShortField(int, short) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
storeShortField(int, short) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
storesLowerCaseIdentifiers() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
storesLowerCaseQuotedIdentifiers() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
storesMixedCaseIdentifiers() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
storesMixedCaseQuotedIdentifiers() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
storeString(int, String) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
storeString(int, String) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
storeString(int, String) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
storeString(int, String) - Method in interface org.apache.openjpa.kernel.OpenJPAStateManager
Set the given external value back into the given field.
storeString(int, String) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
storeStringField(int, String) - Method in interface org.apache.openjpa.enhance.FieldConsumer
Set the value of the given field.
storeStringField(int, String) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
storeStringField(int, String) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
storesUpperCaseIdentifiers() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
storesUpperCaseQuotedIdentifiers() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
storeVersion(OpenJPAStateManager) - Method in class org.apache.openjpa.kernel.PCDataImpl
Store version information from the given state manager.
Strategy - Interface in org.apache.openjpa.jdbc.meta
Interface implemented by all mapping strategies.
Strategy - Annotation Type in org.apache.openjpa.persistence.jdbc
Mapping strategy.
StrategyInstaller - Class in org.apache.openjpa.jdbc.meta
Installs mapping strategies.
StrategyInstaller(MappingRepository) - Constructor for class org.apache.openjpa.jdbc.meta.StrategyInstaller
Constructor; supply repository.
strict - Variable in class org.apache.openjpa.meta.AbstractMetaDataFactory
 
STRING - Static variable in class org.apache.openjpa.meta.JavaTypes
 
StringContains - Class in org.apache.openjpa.kernel.exps
Deprecated. Use matches() instead.
StringContains() - Constructor for class org.apache.openjpa.kernel.exps.StringContains
Deprecated.  
StringDistance - Class in org.apache.openjpa.lib.util
Utilities for calculating string distance.
StringDistance() - Constructor for class org.apache.openjpa.lib.util.StringDistance
 
StringFieldStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Direct mapping from a string value to a column.
StringFieldStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
StringId - Class in org.apache.openjpa.util
OpenJPAId subclass appropriate for String fields.
StringId(Class, String) - Constructor for class org.apache.openjpa.util.StringId
 
StringId(Class, String, boolean) - Constructor for class org.apache.openjpa.util.StringId
 
stringLength(Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
stringLength(Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Returns the number of characters in the String value.
stringLength(Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
stringLengthFunction - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
StringListValue - Class in org.apache.openjpa.lib.conf
A comma-separated list of string values.
StringListValue(String) - Constructor for class org.apache.openjpa.lib.conf.StringListValue
 
StringValue - Class in org.apache.openjpa.lib.conf
A string Value.
StringValue(String) - Constructor for class org.apache.openjpa.lib.conf.StringValue
 
structTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
subclassFetchMode - Variable in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
SubclassFetchMode - Annotation Type in org.apache.openjpa.persistence.jdbc
Determines how to eager-fetch subclass data.
SubclassJoinDiscriminatorStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Discriminator strategy that outer joins to all possible subclass tables to determine the class of an instance.
SubclassJoinDiscriminatorStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.SubclassJoinDiscriminatorStrategy
 
subList(int, int) - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
subList(int, int) - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
subList(int, int) - Method in class org.apache.openjpa.lib.rop.AbstractResultList
 
subList(int, int) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
Subquery - Interface in org.apache.openjpa.kernel.exps
Query value representing a subquery.
subs - Variable in class org.apache.openjpa.util.OpenJPAId
 
SUBS_ANY_JOINABLE - Static variable in interface org.apache.openjpa.jdbc.sql.Select
Constant indicating to select subclasses but without adding any class conditions to the select.
SUBS_EXACT - Static variable in interface org.apache.openjpa.jdbc.sql.Select
Constant indicating to select this class but without adding any class conditions to the select.
SUBS_JOINABLE - Static variable in interface org.apache.openjpa.jdbc.sql.Select
Constant indicating to add conditions to the selcet to select this class and joinable subclasses only.
SUBS_NONE - Static variable in interface org.apache.openjpa.jdbc.sql.Select
Constant indicating to add conditions to the select to select this class only.
substring(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
substring(SQLBuffer, FilterValue, FilterValue, FilterValue) - Method in class org.apache.openjpa.jdbc.sql.AbstractDB2Dictionary
 
substring(SQLBuffer, FilterValue, FilterValue, FilterValue) - Method in class org.apache.openjpa.jdbc.sql.AbstractSQLServerDictionary
 
substring(SQLBuffer, FilterValue, FilterValue, FilterValue) - Method in class org.apache.openjpa.jdbc.sql.AccessDictionary
 
substring(SQLBuffer, FilterValue, FilterValue, FilterValue) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Invoke this database's substring function.
substring(SQLBuffer, FilterValue, FilterValue, FilterValue) - Method in class org.apache.openjpa.jdbc.sql.FirebirdDictionary
 
substring(SQLBuffer, FilterValue, FilterValue, FilterValue) - Method in class org.apache.openjpa.jdbc.sql.HSQLDictionary
 
substring(SQLBuffer, FilterValue, FilterValue, FilterValue) - Method in class org.apache.openjpa.jdbc.sql.InterbaseDictionary
 
substring(SQLBuffer, FilterValue, FilterValue, FilterValue) - Method in class org.apache.openjpa.jdbc.sql.JDataStoreDictionary
 
substring(SQLBuffer, FilterValue, FilterValue, FilterValue) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
substring(SQLBuffer, FilterValue, FilterValue, FilterValue) - Method in class org.apache.openjpa.jdbc.sql.PointbaseDictionary
 
substring(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return a value representing the String.substring(int) function on the given target with the given args.
substring(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
substringFunctionName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
subtract(Value, Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
subtract(Value, Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return a value representing the second value subtracted from the first.
subtract(Value, Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
subtract(Object, Class, Object, Class) - Static method in class org.apache.openjpa.kernel.Filters
Subtract the given values.
suffix - Variable in class org.apache.openjpa.enhance.ApplicationIdTool.Flags
 
SuffixMetaDataFilter - Class in org.apache.openjpa.lib.meta
Filters metadata iteration based on resource name suffix.
SuffixMetaDataFilter(String) - Constructor for class org.apache.openjpa.lib.meta.SuffixMetaDataFilter
Constructor; supply suffix to match against.
sum(Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
sum(Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return the max of the given value for all matches.
sum(Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
SunOneManagedRuntime - Class in org.apache.openjpa.ee
ManagedRuntime implementation for SunONE.
SunOneManagedRuntime() - Constructor for class org.apache.openjpa.ee.SunOneManagedRuntime
 
SuperclassDiscriminatorStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Discriminator strategy that delegates to superclass discriminator.
SuperclassDiscriminatorStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.SuperclassDiscriminatorStrategy
 
SuperclassVersionStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Version strategy that delegates to the suerpclass version.
SuperclassVersionStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.SuperclassVersionStrategy
 
supportedOptions() - Method in interface org.apache.openjpa.conf.OpenJPAConfiguration
Return the set of option strings supported by this runtime.
supportedOptions() - Method in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
supportsAbstractExecutors() - Method in class org.apache.openjpa.datacache.QueryCacheStoreQuery
 
supportsAbstractExecutors() - Method in class org.apache.openjpa.kernel.AbstractStoreQuery
 
supportsAbstractExecutors() - Method in interface org.apache.openjpa.kernel.StoreQuery
Return true if this query supports execution against abstract or interface types.
supportsAlterTableWithAddColumn - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsAlterTableWithAddColumn() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsAlterTableWithDropColumn - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsAlterTableWithDropColumn() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsANSI92EntryLevelSQL() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsANSI92FullSQL() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsANSI92IntermediateSQL() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsAutoAssign - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsBatchUpdates() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsCascadeDeleteAction - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsCascadeUpdateAction - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsCatalogsInDataManipulation() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsCatalogsInIndexDefinitions() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsCatalogsInPrivilegeDefinitions() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsCatalogsInProcedureCalls() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsCatalogsInTableDefinitions() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsColumnAliasing() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsConvert() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsConvert(int, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsCoreSQLGrammar() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsCorrelatedSubqueries() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsCorrelatedSubselect - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsDataDefinitionAndDataManipulationTransactions() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsDataManipulationTransactionsOnly() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsDataStoreExecution() - Method in class org.apache.openjpa.datacache.QueryCacheStoreQuery
 
supportsDataStoreExecution() - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreQuery
 
supportsDataStoreExecution() - Method in class org.apache.openjpa.jdbc.kernel.SQLStoreQuery
 
supportsDataStoreExecution() - Method in class org.apache.openjpa.kernel.AbstractStoreQuery
 
supportsDataStoreExecution() - Method in class org.apache.openjpa.kernel.MethodStoreQuery
 
supportsDataStoreExecution() - Method in interface org.apache.openjpa.kernel.StoreQuery
True if this query supports datastore execution, false if it can only run in memory.
supportsDefaultDeleteAction - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsDefaultUpdateAction - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsDeferredConstraints - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsDeleteAction(int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Whether this database supports the given foreign key delete action.
supportsDifferentTableCorrelationNames() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsEagerSelect(Select, OpenJPAStateManager, JDBCStore, ClassMapping, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
supportsEagerSelect(Select, OpenJPAStateManager, JDBCStore, ClassMapping, JDBCFetchConfiguration) - Method in interface org.apache.openjpa.jdbc.meta.ClassStrategy
Return true if this strategy can perform the given select from the given base mapping.
supportsEagerSelect(Select, OpenJPAStateManager, JDBCStore, ClassMapping, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractClassStrategy
 
supportsEagerSelect(Select, OpenJPAStateManager, JDBCStore, ClassMapping, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.FullClassStrategy
 
supportsEagerSelect(Select, OpenJPAStateManager, JDBCStore, ClassMapping, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.VerticalClassStrategy
 
supportsExpressionsInOrderBy() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsExtendedSQLGrammar() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsForeignKeys - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsFullOuterJoins() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsGetGeneratedKeys() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsGroupBy() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsGroupByBeyondSelect() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsGroupByUnrelated() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsHaving - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsIncrementalFlush() - Method in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSavepointManager
 
supportsIncrementalFlush() - Method in class org.apache.openjpa.kernel.InMemorySavepointManager
 
supportsIncrementalFlush() - Method in interface org.apache.openjpa.kernel.SavepointManager
Return whether the savepoints generated by this manager can handle incremental flushes to the datastore.
supportsInMemoryExecution() - Method in class org.apache.openjpa.datacache.QueryCacheStoreQuery
 
supportsInMemoryExecution() - Method in class org.apache.openjpa.kernel.AbstractStoreQuery
 
supportsInMemoryExecution() - Method in class org.apache.openjpa.kernel.ExpressionStoreQuery
 
supportsInMemoryExecution() - Method in class org.apache.openjpa.kernel.MethodStoreQuery
 
supportsInMemoryExecution() - Method in interface org.apache.openjpa.kernel.StoreQuery
True if this query supports in-memory execution, false if it can only run against the datastore.
supportsIntegrityEnhancementFacility() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsLikeEscapeClause() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsLimitedOuterJoins() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsLocking(Select) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Returns true if a "FOR UPDATE" clause can be used for the specified Select object.
supportsLocking() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
supportsLocking() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
supportsLocking(Select) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
supportsLocking() - Method in interface org.apache.openjpa.jdbc.sql.SelectExecutor
Whether this select can be executed for update.
supportsLocking() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
supportsLockingWithDistinctClause - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsLockingWithInnerJoin - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsLockingWithMultipleTables - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsLockingWithOrderClause - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsLockingWithOuterJoin - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsLockingWithSelectRange - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsMinimumSQLGrammar() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsMixedCaseIdentifiers() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsMixedCaseQuotedIdentifiers() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsModOperator - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsMultipleNontransactionalResultSets - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsMultipleOpenResults() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsMultipleResultSets() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsMultipleTransactions() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsNamedParameters() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsNonNullableColumns() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsNullDeleteAction - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsNullTableForGetColumns - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsNullTableForGetImportedKeys - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsNullTableForGetIndexInfo - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsNullTableForGetPrimaryKeys - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsNullUpdateAction - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsOpenCursorsAcrossCommit() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsOpenCursorsAcrossRollback() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsOpenStatementsAcrossCommit() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsOpenStatementsAcrossRollback() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsOrderByUnrelated() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsOuterJoins() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsParameterDeclarations() - Method in class org.apache.openjpa.datacache.QueryCacheStoreQuery
 
supportsParameterDeclarations() - Method in class org.apache.openjpa.jdbc.kernel.SQLStoreQuery
 
supportsParameterDeclarations() - Method in class org.apache.openjpa.kernel.AbstractStoreQuery
 
supportsParameterDeclarations() - Method in interface org.apache.openjpa.kernel.StoreQuery
Whether this query supports declared parameters.
supportsPositionedDelete() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsPositionedUpdate() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsQueryTimeout - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsRandomAccess() - Method in class org.apache.openjpa.jdbc.kernel.GenericResultObjectProvider
 
supportsRandomAccess() - Method in class org.apache.openjpa.jdbc.kernel.SelectResultObjectProvider
 
supportsRandomAccess() - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
Returns false by default.
supportsRandomAccess(boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
supportsRandomAccess(boolean) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
supportsRandomAccess() - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
supportsRandomAccess() - Method in interface org.apache.openjpa.jdbc.sql.Result
Return true if the result supports random access.
supportsRandomAccess() - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
supportsRandomAccess(boolean) - Method in interface org.apache.openjpa.jdbc.sql.SelectExecutor
Return whether this select can support a random access result set type.
supportsRandomAccess(boolean) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
supportsRandomAccess() - Method in class org.apache.openjpa.kernel.AbstractPCResultObjectProvider
Override if desired.
supportsRandomAccess() - Method in class org.apache.openjpa.lib.rop.ListResultObjectProvider
 
supportsRandomAccess() - Method in class org.apache.openjpa.lib.rop.MergedResultObjectProvider
 
supportsRandomAccess() - Method in class org.apache.openjpa.lib.rop.RangeResultObjectProvider
 
supportsRandomAccess() - Method in interface org.apache.openjpa.lib.rop.ResultObjectProvider
Return true if this provider supports random access.
supportsRandomAccessResultSet(Select, boolean) - Method in class org.apache.openjpa.jdbc.sql.DB2Dictionary
 
supportsRandomAccessResultSet(Select, boolean) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return false if the given select requires a forward-only result set.
supportsRandomAccessResultSet(Select, boolean) - Method in class org.apache.openjpa.jdbc.sql.InformixDictionary
 
supportsRestrictDeleteAction - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsRestrictUpdateAction - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsResultSetConcurrency(int, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsResultSetHoldability(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsResultSetType(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsSavepoints() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsSchemaForGetColumns - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsSchemaForGetTables - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsSchemasInDataManipulation() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsSchemasInIndexDefinitions() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsSchemasInPrivilegeDefinitions() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsSchemasInProcedureCalls() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsSchemasInTableDefinitions() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsSelect(Select, int, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
supportsSelect(Select, int, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration) - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Return whether this mapping can perform the given select type.
supportsSelect(Select, int, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
supportsSelect(Select, int, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedFieldStrategy
 
supportsSelect(Select, int, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
supportsSelect(Select, int, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.MapTableFieldStrategy
 
supportsSelect(Select, int, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
supportsSelect(Select, int, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
supportsSelect(Select, int, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.StoreCollectionFieldStrategy
 
supportsSelect(Select, int, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
supportsSelectEndIndex - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsSelectForUpdate - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsSelectForUpdate() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsSelectStartIndex - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsSetFetchSize - Variable in class org.apache.openjpa.jdbc.sql.PostgresDictionary
Some Postgres drivers do not support the Statement.setFetchSize(int) method.
supportsStatementPooling() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsStoredProcedures() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsSubqueriesInComparisons() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsSubqueriesInExists() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsSubqueriesInIns() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsSubqueriesInQuantifieds() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsSubselect - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsTableCorrelationNames() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsTimestampNanos - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsTransactionIsolationLevel(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsTransactions() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsUnion() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsUnionAll() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
supportsUniqueConstraints - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
supportsUpdateAction(int) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Whether this database supports the given foreign key update action.
swapSchemaAndCatalog - Variable in class org.apache.openjpa.jdbc.sql.InformixDictionary
Informix JDBC metadata for all known drivers returns with the table catalog and the table schema name swapped.
SybaseDictionary - Class in org.apache.openjpa.jdbc.sql
Dictionary for Sybase.
SybaseDictionary() - Constructor for class org.apache.openjpa.jdbc.sql.SybaseDictionary
 
syncColumn(MetaDataContext, Column, int, boolean, Table, Table, Object, boolean) - Static method in class org.apache.openjpa.jdbc.meta.MappingInfo
Create a copy of the given column with the raw mapping information set correctly, and without settings that match defaults.
syncColumns(MetaDataContext, Column[], boolean) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Sets internal column information to match the given mapped columns.
syncForeignKey(MetaDataContext, ForeignKey, Table, Table) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Sets internal constraint and column information to match given mapped constraint.
synchronizeMappings - Variable in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
syncIndex(MetaDataContext, Index) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Sets internal index information to match given mapped index.
syncMappingInfo() - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Update MappingInfo with our current mapping information.
syncMappingInfo() - Method in class org.apache.openjpa.jdbc.meta.Discriminator
Update MappingInfo with our current mapping information.
syncMappingInfo() - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Update MappingInfo with our current mapping information.
syncMappingInfo() - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
Update MappingInfo with our current mapping information.
syncMappingInfo() - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
syncMappingInfo() - Method in class org.apache.openjpa.jdbc.meta.Version
Update MappingInfo with our current mapping information.
syncOrderColumn(FieldMapping) - Method in class org.apache.openjpa.jdbc.meta.FieldMappingInfo
Synchronize internal order column information with the given field.
syncStrategy(FieldMapping) - Method in class org.apache.openjpa.jdbc.meta.FieldMappingInfo
Synchronize internal mapping strategy information with the given field.
syncUnique(MetaDataContext, Unique) - Method in class org.apache.openjpa.jdbc.meta.MappingInfo
Sets internal constraint information to match given mapped constraint.
syncVersion(OpenJPAStateManager, Object) - Method in class org.apache.openjpa.abstractstore.AbstractStoreManager
Since this store manager does not provide optimistic locking support, this method always returns true.
syncVersion(OpenJPAStateManager, Object) - Method in class org.apache.openjpa.datacache.DataCacheStoreManager
 
syncVersion(OpenJPAStateManager, Object) - Method in class org.apache.openjpa.jdbc.kernel.JDBCStoreManager
 
syncVersion(OpenJPAStateManager, Object) - Method in class org.apache.openjpa.kernel.DelegatingStoreManager
 
syncVersion(OpenJPAStateManager, Object) - Method in interface org.apache.openjpa.kernel.StoreManager
Update the version information in the given state manager to the version stored in the data store.
syncVersion(OpenJPAStateManager, Object) - Method in class org.apache.openjpa.xmlstore.XMLStoreManager
 
syncWith(ClassMapping) - Method in class org.apache.openjpa.jdbc.meta.ClassMappingInfo
Synchronize internal information with the mapping data for the given class.
syncWith(Discriminator) - Method in class org.apache.openjpa.jdbc.meta.DiscriminatorMappingInfo
Synchronize internal information with the mapping data for the given discriminator.
syncWith(FieldMapping) - Method in class org.apache.openjpa.jdbc.meta.FieldMappingInfo
Synchronize internal information with the mapping data for the given field.
syncWith(ValueMapping) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingInfo
Synchronize internal information with the mapping data for the given value.
syncWith(Version) - Method in class org.apache.openjpa.jdbc.meta.VersionMappingInfo
Synchronize internal information with the mapping data for the given version.
syncWithManagedTransaction() - Method in interface org.apache.openjpa.kernel.Broker
Attempt to synchronize with a current managed transaction, returning true if successful, false if no managed transaction is active.
syncWithManagedTransaction() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
syncWithManagedTransaction() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
SYNTAX_DATABASE - Static variable in interface org.apache.openjpa.jdbc.sql.JoinSyntaxes
Native database join syntax; outer joins are supported.
SYNTAX_SQL92 - Static variable in interface org.apache.openjpa.jdbc.sql.JoinSyntaxes
ANSI SQL 92 join syntax; outer joins are supported.
SYNTAX_TRADITIONAL - Static variable in interface org.apache.openjpa.jdbc.sql.JoinSyntaxes
Traditional join syntax; outer joins are not supported.
SYNTHETIC - Static variable in class org.apache.openjpa.meta.ClassMetaData
Value for using a synthetic detached state field, which is the default.
SYSTEM_LOADER - Static variable in class org.apache.openjpa.lib.util.MultiClassLoader
The standard system class loader.
systemSchemas - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
systemSchemaSet - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
systemTables - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
systemTableSet - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 

T

tab() - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
tab(int) - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
Table - Class in org.apache.openjpa.jdbc.schema
Represents a database table.
Table() - Constructor for class org.apache.openjpa.jdbc.schema.Table
Default constructor.
Table(String, Schema) - Constructor for class org.apache.openjpa.jdbc.schema.Table
Constructor.
TABLE_ASSOCIATION - Static variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Association table.
TABLE_BASE - Static variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Primary table for a new base class.
TABLE_NONE - Static variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Unmapped table.
TABLE_SECONDARY - Static variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Secondary table of an existing class.
TABLE_SECONDARY_OUTER - Static variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Secondary table of an existing class.
TABLE_SUBCLASS - Static variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool
Subclass table.
tableForUpdateClause - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
TableJDBCSeq - Class in org.apache.openjpa.jdbc.kernel
JDBCSeq implementation that uses a database table for sequence number generation.
TableJDBCSeq() - Constructor for class org.apache.openjpa.jdbc.kernel.TableJDBCSeq
 
TableJDBCSeq.Status - Class in org.apache.openjpa.jdbc.kernel
Helper struct to hold status information.
TableJDBCSeq.Status() - Constructor for class org.apache.openjpa.jdbc.kernel.TableJDBCSeq.Status
 
TableSchemaFactory - Class in org.apache.openjpa.jdbc.schema
Factory that uses an XML schema definition stored in a database table to record the system schema.
TableSchemaFactory() - Constructor for class org.apache.openjpa.jdbc.schema.TableSchemaFactory
 
tableType - Variable in class org.apache.openjpa.jdbc.sql.MySQLDictionary
The MySQL table type to use when creating tables; defaults to innodb.
tableTypes - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
TAG - Static variable in class org.apache.openjpa.jdbc.kernel.exps.GetColumn
 
TAG - Static variable in class org.apache.openjpa.jdbc.kernel.exps.SQLEmbed
 
TAG - Static variable in class org.apache.openjpa.jdbc.kernel.exps.SQLExpression
Deprecated.  
TAG - Static variable in class org.apache.openjpa.jdbc.kernel.exps.SQLValue
Deprecated.  
TAG - Static variable in class org.apache.openjpa.kernel.exps.StringContains
Deprecated.  
TAG - Static variable in class org.apache.openjpa.kernel.exps.WildcardMatch
Deprecated.  
takeOver(WaitQueue.WaitNode) - Method in interface org.apache.openjpa.lib.util.concurrent.WaitQueue.QueuedSync
 
TCLEAN - Static variable in class org.apache.openjpa.kernel.PCState
Transient-Clean
TCPRemoteCommitProvider - Class in org.apache.openjpa.event
TCP-based implementation of RemoteCommitProvider that listens for object modifications and propagates those changes to other RemoteCommitProviders over TCP sockets.
TCPRemoteCommitProvider() - Constructor for class org.apache.openjpa.event.TCPRemoteCommitProvider
 
TDIRTY - Static variable in class org.apache.openjpa.kernel.PCState
Transient-Dirty
TemporaryClassLoader - Class in org.apache.openjpa.lib.util
ClassLoader implementation that allows classes to be temporarily loaded and then thrown away.
TemporaryClassLoader(ClassLoader) - Constructor for class org.apache.openjpa.lib.util.TemporaryClassLoader
 
THREAD_LOADER - Static variable in class org.apache.openjpa.lib.util.MultiClassLoader
Marker that will be replaced with the context loader of the current thread whenever it is discovered in the class loader list.
throwException(Code, Class) - Method in class org.apache.openjpa.enhance.DynamicStorageGenerator
Throw an exception of the given type.
throwException(OpenJPAStateManager, FieldMetaData) - Method in class org.apache.openjpa.kernel.InverseManager
Throw an inconsistency exception
throwsDec(int) - Method in class org.apache.openjpa.lib.util.CodeFormat
Append the given value to the internal buffer.
TIME - Static variable in class org.apache.openjpa.jdbc.meta.JavaSQLTypes
 
timedJoin(Thread, long) - Method in class org.apache.openjpa.lib.util.concurrent.TimeUnit
Performs a timed Thread.join using this time unit.
timedWait(Object, long) - Method in class org.apache.openjpa.lib.util.concurrent.TimeUnit
Performs a timed Object.wait using this time unit.
TimeSeededSeq - Class in org.apache.openjpa.kernel
A simplistic implementation of a Seq used to provide datastore ids.
TimeSeededSeq() - Constructor for class org.apache.openjpa.kernel.TimeSeededSeq
 
TIMESTAMP - Static variable in class org.apache.openjpa.jdbc.meta.JavaSQLTypes
 
timestampTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
TimestampVersionStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Uses a timestamp for optimistic versioning.
TimestampVersionStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.TimestampVersionStrategy
 
timeTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
TimeUnit - Class in org.apache.openjpa.lib.util.concurrent
A TimeUnit represents time durations at a given unit of granularity and provides utility methods to convert across units, and to perform timing and delay operations in these units.
tinyintTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
TLOADED - Static variable in class org.apache.openjpa.kernel.PCState
Transient-Loaded
tmpClassLoader - Variable in class org.apache.openjpa.enhance.PCEnhancer.Flags
 
toArray() - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
toArray(Object[]) - Method in class org.apache.openjpa.kernel.DelegatingResultList
 
toArray() - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
toArray(Object[]) - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
toArray() - Method in class org.apache.openjpa.lib.rop.AbstractNonSequentialResultList
 
toArray(Object[]) - Method in class org.apache.openjpa.lib.rop.AbstractNonSequentialResultList
 
toArray() - Method in class org.apache.openjpa.lib.rop.AbstractSequentialResultList
 
toArray(Object[]) - Method in class org.apache.openjpa.lib.rop.AbstractSequentialResultList
 
toArray() - Method in class org.apache.openjpa.lib.rop.ListResultList
 
toArray(Object[]) - Method in class org.apache.openjpa.lib.rop.ListResultList
 
toArray() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashSet
 
toArray(Object[]) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashSet
 
toArray() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashSet
 
toArray(Object[]) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashSet
 
toArray() - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
toArray(Object[]) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
toArray() - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArraySet
Returns an array containing all of the elements in this set.
toArray(Object[]) - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArraySet
Returns an array containing all of the elements in this set; the runtime type of the returned array is that of the specified array.
toArray() - Method in class org.apache.openjpa.lib.util.ReferenceHashSet
 
toArray(Object[]) - Method in class org.apache.openjpa.lib.util.ReferenceHashSet
 
toArray(Collection, Class) - Static method in class org.apache.openjpa.meta.JavaTypes
Helper method to return the given collection as an array.
toArray() - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
toArray(Object[]) - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
toBroker(EntityManager) - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
Return the underlying broker for the given entity manager facade.
toBrokerFactory(EntityManagerFactory) - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
Return the underlying broker factory for the given persistence manager factory facade.
toBulkOperation(ClassMapping, Select, JDBCStore, Object[], Map) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Returns the SQL for a bulk operation, either a DELETE or an UPDATE.
toBytes(long) - Static method in class org.apache.openjpa.lib.util.Bytes
Returns a 8-byte array built from a long.
toBytes(long, byte[]) - Static method in class org.apache.openjpa.lib.util.Bytes
Build a 8-byte array from a long.
toClass(Object) - Method in class org.apache.openjpa.meta.InheritanceComparator
Subclasses can override this method to extract the class to compare on from the elements of the collection.
toClass(Object) - Method in class org.apache.openjpa.meta.MetaDataInheritanceComparator
 
toCollection(Object) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapInverseKeyFieldStrategy
 
toCollection(Object) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationMapTableFieldStrategy
 
toCollection(Object) - Method in class org.apache.openjpa.jdbc.meta.strats.StoreCollectionFieldStrategy
Convert the field value to a collection.
toData(FieldMetaData, Object, StoreContext) - Method in class org.apache.openjpa.datacache.DataCachePCDataImpl
 
toData(FieldMetaData, Object, StoreContext) - Method in class org.apache.openjpa.kernel.AbstractPCData
Transform the given field value to a data value for caching.
toDataStoreValue(Object) - Method in interface org.apache.openjpa.jdbc.kernel.exps.FilterValue
Transform the given value into its datastore equivalent.
toDataStoreValue(Select, ExpContext, ExpState, Object) - Method in interface org.apache.openjpa.jdbc.kernel.exps.Val
Return the datastore value of the given object in the context of this value.
toDataStoreValue(Object, Column[], JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
Return the given column value(s) for the given object.
toDataStoreValue(Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
toDataStoreValue(Object, JDBCStore) - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Translate the given external field value to its datastore equivalent.
toDataStoreValue(Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
toDataStoreValue(ValueMapping, Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractValueHandler
 
toDataStoreValue(ValueMapping, Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.ByteArrayValueHandler
 
toDataStoreValue(ValueMapping, Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.CharArrayStreamValueHandler
 
toDataStoreValue(ValueMapping, Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.CharArrayValueHandler
 
toDataStoreValue(Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedFieldStrategy
 
toDataStoreValue(OpenJPAStateManager, ValueMapping, JDBCStore, Column[], Object, int) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedValueHandler
Helper to convert an object value to its datastore equivalent.
toDataStoreValue(ValueMapping, Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.EnumValueHandler
 
toDataStoreValue(Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
toDataStoreValue(ValueMapping, Object, Column[], JDBCStore) - Static method in class org.apache.openjpa.jdbc.meta.strats.HandlerStrategies
Convert the given object to its datastore value(s).
toDataStoreValue(ValueMapping, Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.ImmutableValueHandler
 
toDataStoreValue(ValueMapping, Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.ObjectIdValueHandler
 
toDataStoreValue(Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
toDataStoreValue(ValueMapping, Object, JDBCStore) - Static method in class org.apache.openjpa.jdbc.meta.strats.RelationStrategies
Return the given object as its foreign key values.
toDataStoreValue(Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyInverseKeyFieldStrategy
 
toDataStoreValue(Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyTableFieldStrategy
 
toDataStoreValue(Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
toDataStoreValue(ValueMapping, Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.UntypedPCValueHandler
 
toDataStoreValue(ValueMapping, Object, JDBCStore) - Method in interface org.apache.openjpa.jdbc.meta.ValueHandler
Translate the given value to its datastore equivalent.
toDays(long) - Method in class org.apache.openjpa.lib.util.concurrent.TimeUnit
Equivalent to DAYS.convert(duration, this).
toDelete(ClassMapping, Select, JDBCStore, Object[]) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Create a DELETE statement for the specified Select.
toEmbeddedData(Object, StoreContext) - Method in class org.apache.openjpa.kernel.AbstractPCData
Return the value to cache for the given embedded PC.
toEmbeddedDataStoreValue(Object, JDBCStore) - Method in interface org.apache.openjpa.jdbc.meta.Embeddable
Convert the given Java value to its datastore equivalent.
toEmbeddedDataStoreValue(Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
toEmbeddedDataStoreValue(Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
toEmbeddedDataStoreValue(Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
toEmbeddedDataStoreValue(Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
toEmbeddedField(OpenJPAStateManager, ValueMetaData, Object, FetchConfiguration, Object) - Method in class org.apache.openjpa.kernel.AbstractPCData
Transform the given data into an embedded PC field value.
toEmbeddedObjectValue(Object) - Method in interface org.apache.openjpa.jdbc.meta.Embeddable
Convert the given datastore value to its Java equivalent.
toEmbeddedObjectValue(Object) - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
toEmbeddedObjectValue(Object) - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
toEmbeddedObjectValue(Object) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
toEmbeddedObjectValue(Object) - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
toEntityManager(Broker) - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
Return a persistence manager facade to the given broker retaining previously associated persistence context type.
toEntityManagerFactory(BrokerFactory) - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
 
toField(OpenJPAStateManager, FieldMetaData, Object, FetchConfiguration, Object) - Method in class org.apache.openjpa.kernel.AbstractPCData
Transform the given data value into its field value.
toHours(long) - Method in class org.apache.openjpa.lib.util.concurrent.TimeUnit
Equivalent to HOURS.convert(duration, this).
token - Variable in class org.apache.openjpa.enhance.ApplicationIdTool.Flags
 
TOKEN_DEFAULT - Static variable in class org.apache.openjpa.enhance.ApplicationIdTool
 
toKeyDataStoreValue(Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
toKeyDataStoreValue(Object, JDBCStore) - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Translate the given key value to its datastore equivalent.
toKeyDataStoreValue(Object, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
toList(Object, Class, boolean) - Static method in class org.apache.openjpa.meta.JavaTypes
Helper method to return the given array value as a collection.
toLong(byte[]) - Static method in class org.apache.openjpa.lib.util.Bytes
Build a long from first 8 bytes of the array.
toLowerCase(Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
toLowerCase(Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return the upper case of the given value.
toLowerCase(Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
toLowerCaseFunction - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
toMicros(long) - Method in class org.apache.openjpa.lib.util.concurrent.TimeUnit
Equivalent to MICROSECONDS.convert(duration, this).
toMillis(long) - Method in class org.apache.openjpa.lib.util.concurrent.TimeUnit
Equivalent to MILLISECONDS.convert(duration, this).
toMinutes(long) - Method in class org.apache.openjpa.lib.util.concurrent.TimeUnit
Equivalent to MINUTES.convert(duration, this).
toNanos(long) - Method in class org.apache.openjpa.lib.util.concurrent.TimeUnit
Equivalent to NANOSECONDS.convert(duration, this).
toNativeJoin(Join) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Use the given join instance to create SQL joining its tables in the database's native syntax.
toNativeJoin(Join) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
toNestedData(ValueMetaData, Object, StoreContext) - Method in class org.apache.openjpa.datacache.DataCachePCDataImpl
 
toNestedData(ValueMetaData, Object, StoreContext) - Method in class org.apache.openjpa.kernel.AbstractPCData
Transform the given nested value to a cachable value.
toNestedField(OpenJPAStateManager, ValueMetaData, Object, FetchConfiguration, Object) - Method in class org.apache.openjpa.kernel.AbstractPCData
Transform the given data value to its field value.
toObjectValue(ValueMapping, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractValueHandler
 
toObjectValue(ValueMapping, Object, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractValueHandler
 
toObjectValue(ValueMapping, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.ByteArrayValueHandler
 
toObjectValue(ValueMapping, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.CharArrayStreamValueHandler
 
toObjectValue(ValueMapping, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.CharArrayValueHandler
 
toObjectValue(OpenJPAStateManager, ValueMapping, Object, JDBCStore, JDBCFetchConfiguration, Column[], int) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedValueHandler
Helper to convert a datastore value to its object equivalent.
toObjectValue(ValueMapping, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.EnumValueHandler
 
toObjectValue(ValueMapping, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.ObjectIdValueHandler
 
toObjectValue(ValueMapping, Object, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.meta.strats.UntypedPCValueHandler
 
toObjectValue(ValueMapping, Object) - Method in interface org.apache.openjpa.jdbc.meta.ValueHandler
Translate the given datastore value into its Java equivalent.
toObjectValue(ValueMapping, Object, OpenJPAStateManager, JDBCStore, JDBCFetchConfiguration) - Method in interface org.apache.openjpa.jdbc.meta.ValueHandler
Translate the given datastore value into its Java equivalent.
tool - Variable in class org.apache.openjpa.jdbc.meta.PropertiesReverseCustomizer
 
toOpenJPAObjectId(ClassMetaData, Object) - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
Translate from a Persistence identity object to a OpenJPA one.
toOpenJPAObjectIds(ClassMetaData, Object...) - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
Return an array of OpenJPA oids for the given native oid array.
toOpenJPAObjectIds(ClassMetaData, Collection) - Static method in class org.apache.openjpa.persistence.OpenJPAPersistence
Return a collection of OpenJPA oids for the given native oid collection.
toOpenJPAProperties() - Method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
Return a Map containing the properties necessary to create a Configuration that reflects the information in this persistence unit info.
toOpenJPAProperties(PersistenceUnitInfo) - Static method in class org.apache.openjpa.persistence.PersistenceUnitInfoImpl
Return a Map containing the properties necessary to create a Configuration that reflects the information in the given persistence unit info.
toOperation(String, SQLBuffer, SQLBuffer, SQLBuffer, SQLBuffer, SQLBuffer, SQLBuffer, boolean, boolean, long, long) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Return the SQL for the given selecting operation.
toOperation(String, SQLBuffer, SQLBuffer, SQLBuffer, SQLBuffer, SQLBuffer, SQLBuffer, boolean, boolean, long, long) - Method in class org.apache.openjpa.jdbc.sql.HSQLDictionary
 
toOrderAlias(int) - Static method in class org.apache.openjpa.jdbc.sql.SelectImpl
Helper method to return the proper order alias for the given order column index.
toPersistenceException(Throwable) - Static method in class org.apache.openjpa.persistence.PersistenceExceptions
Convert the given throwable to the proper persistence exception.
toPKValues(Object, ClassMetaData) - Static method in class org.apache.openjpa.util.ApplicationIds
Return the primary key values for the given object id.
toPolymorphicConstant(NonpolymorphicType) - Static method in class org.apache.openjpa.persistence.jdbc.AnnotationPersistenceMappingParser
Return the ValueMapping POLY_* constant for the given enum value.
toProperties(boolean) - Method in interface org.apache.openjpa.lib.conf.Configuration
A properties representation of this Configuration.
toProperties(boolean) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
toRelationData(Object, StoreContext) - Method in class org.apache.openjpa.kernel.AbstractPCData
Return the value to cache for the given object.
toRelationDataStoreValue(OpenJPAStateManager, Column) - Method in interface org.apache.openjpa.jdbc.meta.RelationId
Return the serialized value for the given related object, now that its id has been assigned.
toRelationDataStoreValue(OpenJPAStateManager, Column) - Method in class org.apache.openjpa.jdbc.meta.strats.UntypedPCValueHandler
 
toRelationField(OpenJPAStateManager, ValueMetaData, Object, FetchConfiguration, Object) - Method in class org.apache.openjpa.kernel.AbstractPCData
Transform the given data into a relation field value.
toResult(StoreQuery.Executor, ResultObjectProvider, StoreQuery.Range) - Method in class org.apache.openjpa.kernel.QueryImpl
Return the query result for the given result object provider.
toSeconds(long) - Method in class org.apache.openjpa.lib.util.concurrent.TimeUnit
Equivalent to SECONDS.convert(duration, this).
toSelect(Select, boolean, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Create a SELECT statement in the proper join syntax for the given instance.
toSelect(SQLBuffer, JDBCFetchConfiguration, SQLBuffer, SQLBuffer, SQLBuffer, SQLBuffer, SQLBuffer, boolean, boolean, long, long) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Combine the given components into a SELECT statement.
toSelect(SQLBuffer, JDBCFetchConfiguration, SQLBuffer, SQLBuffer, SQLBuffer, SQLBuffer, SQLBuffer, boolean, boolean, long, long) - Method in class org.apache.openjpa.jdbc.sql.EmpressDictionary
 
toSelect(boolean, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
toSelect(boolean, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
toSelect(SQLBuffer, JDBCFetchConfiguration, SQLBuffer, SQLBuffer, SQLBuffer, SQLBuffer, SQLBuffer, boolean, boolean, long, long) - Method in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
toSelect(boolean, JDBCFetchConfiguration) - Method in interface org.apache.openjpa.jdbc.sql.SelectExecutor
Return this select as a SQL statement formatted for the current dictionary.
toSelect(boolean, JDBCFetchConfiguration) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
toSelectCount(Select) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Create a SELECT COUNT statement in the proper join syntax for the given instance.
toSelectCount() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
toSelectCount() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
toSelectCount() - Method in interface org.apache.openjpa.jdbc.sql.SelectExecutor
Return this select as a COUNT SQL statement formatted for the current dictionary.
toSelectCount() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
toSequence(Class, String) - Method in interface org.apache.openjpa.meta.SequenceMetaData.SequenceFactory
Transform the given class named in metadata into a sequence.
toShort(byte[]) - Static method in class org.apache.openjpa.lib.util.Bytes
Build a short from first 2 bytes of the array.
toSQL92Join(Join, boolean, boolean) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Use the given join instance to create SQL joining its tables in the SQL92 style.
toString() - Method in class org.apache.openjpa.conf.OpenJPAVersion
 
toString() - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
toString() - Method in class org.apache.openjpa.datacache.QueryKey
 
toString() - Method in class org.apache.openjpa.event.MethodLifecycleCallbacks
 
toString() - Method in class org.apache.openjpa.jdbc.meta.Discriminator
 
toString() - Method in class org.apache.openjpa.jdbc.meta.QueryResultMapping
 
toString() - Method in class org.apache.openjpa.jdbc.meta.Version
 
toString() - Method in class org.apache.openjpa.jdbc.schema.Column
Returns the column name.
toString() - Method in class org.apache.openjpa.jdbc.schema.Constraint
 
toString() - Method in class org.apache.openjpa.jdbc.schema.Schema
 
toString() - Method in class org.apache.openjpa.jdbc.schema.Sequence
 
toString() - Method in class org.apache.openjpa.jdbc.schema.Table
 
toString(DatabaseMetaData) - Static method in class org.apache.openjpa.jdbc.sql.DBDictionaryFactory
Return a string containing all the property values of the given database metadata.
toString() - Method in class org.apache.openjpa.jdbc.sql.Join
 
toString() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion
 
toString() - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
toString() - Method in class org.apache.openjpa.jdbc.sql.Raw
 
toString() - Method in interface org.apache.openjpa.jdbc.sql.Select
Implement toString to generate SQL string for profiling/debuggging.
toString() - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
toString() - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
toString() - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
toString() - Method in class org.apache.openjpa.kernel.QueryImpl
 
toString() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
toString() - Method in class org.apache.openjpa.lib.jdbc.DelegatingConnection
 
toString() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
toString() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDataSource
 
toString() - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
toString() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
toString() - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
toString() - Method in class org.apache.openjpa.lib.rop.RandomAccessResultList
 
toString() - Method in class org.apache.openjpa.lib.util.CodeFormat
Return the internal buffer as a string.
toString() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap.Entry
 
toString() - Method in class org.apache.openjpa.lib.util.concurrent.CopyOnWriteArrayList
 
toString() - Method in class org.apache.openjpa.lib.util.concurrent.ReentrantLock
Returns a string identifying this lock, as well as its lock state.
toString() - Method in class org.apache.openjpa.lib.util.concurrent.TimeUnit
 
toString() - Method in class org.apache.openjpa.lib.util.Localizer.Message
 
toString() - Method in class org.apache.openjpa.lib.util.ParameterTemplate
Return a copy of the internal value template with all parameters substituted with their current values.
toString() - Method in class org.apache.openjpa.meta.ClassMetaData
 
toString() - Method in class org.apache.openjpa.meta.FetchGroup
 
toString() - Method in class org.apache.openjpa.meta.FieldMetaData
 
toString() - Method in class org.apache.openjpa.meta.QueryMetaData
 
toString() - Method in class org.apache.openjpa.meta.SequenceMetaData
 
toString() - Method in class org.apache.openjpa.meta.ValueMetaDataImpl
 
toString() - Method in exception org.apache.openjpa.persistence.ArgumentException
 
toString() - Method in exception org.apache.openjpa.persistence.EntityExistsException
 
toString() - Method in exception org.apache.openjpa.persistence.EntityNotFoundException
 
toString() - Method in exception org.apache.openjpa.persistence.InvalidStateException
 
toString() - Method in exception org.apache.openjpa.persistence.NonUniqueResultException
 
toString() - Method in exception org.apache.openjpa.persistence.NoResultException
 
toString() - Method in exception org.apache.openjpa.persistence.OptimisticLockException
 
toString() - Method in exception org.apache.openjpa.persistence.PersistenceException
 
toString() - Method in exception org.apache.openjpa.persistence.RollbackException
 
toString() - Method in exception org.apache.openjpa.persistence.TransactionRequiredException
 
toString() - Method in class org.apache.openjpa.util.ByteId
 
toString() - Method in class org.apache.openjpa.util.CacheMap
 
toString() - Method in class org.apache.openjpa.util.CharId
 
toString() - Method in class org.apache.openjpa.util.DateId
 
toString(Object) - Static method in class org.apache.openjpa.util.Exceptions
Safely stringify the given object.
toString(Collection) - Static method in class org.apache.openjpa.util.Exceptions
Safely stringify the given objects.
toString(ExceptionInfo) - Static method in class org.apache.openjpa.util.Exceptions
Stringify the given exception.
toString() - Method in class org.apache.openjpa.util.IntId
 
toString() - Method in exception org.apache.openjpa.util.LockException
 
toString() - Method in exception org.apache.openjpa.util.OpenJPAException
 
toString() - Method in class org.apache.openjpa.util.OpenJPAId
 
toString() - Method in class org.apache.openjpa.util.ShortId
 
toString() - Method in class org.apache.openjpa.util.StringId
 
toString() - Method in class org.apache.openjpa.xmlstore.ObjectData
 
toTraditionalJoin(Join) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
Use the given join instance to create SQL joining its tables in the traditional style.
toUpdate(ClassMapping, Select, JDBCStore, Object[], Map) - Method in class org.apache.openjpa.jdbc.sql.DBDictionary
 
toUpperCase(Value) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
toUpperCase(Value) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Return the upper case of the given value.
toUpperCase(Value) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
toUpperCaseFunction - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
toXMLName(String) - Static method in class org.apache.openjpa.lib.conf.ConfigurationImpl
Convert propName to a lowercase-with-hyphens-style string.
trace(Object) - Method in class org.apache.openjpa.lib.log.AbstractLog
 
trace(Object, Throwable) - Method in class org.apache.openjpa.lib.log.AbstractLog
 
trace(Object) - Method in class org.apache.openjpa.lib.log.CommonsLogFactory.LogAdapter
 
trace(Object, Throwable) - Method in class org.apache.openjpa.lib.log.CommonsLogFactory.LogAdapter
 
TRACE - Static variable in interface org.apache.openjpa.lib.log.Log
 
trace(Object) - Method in interface org.apache.openjpa.lib.log.Log
Write out a log message at the Log.TRACE level with the stringification of o as the body of the message.
trace(Object, Throwable) - Method in interface org.apache.openjpa.lib.log.Log
Write out a log message at the Log.TRACE level with the stringification of o as the body of the message, also outputting t to the log.
trace(Object) - Method in class org.apache.openjpa.lib.log.Log4JLogFactory.LogAdapter
 
trace(Object, Throwable) - Method in class org.apache.openjpa.lib.log.Log4JLogFactory.LogAdapter
 
trace(Object) - Method in class org.apache.openjpa.lib.log.NoneLogFactory.NoneLog
 
trace(Object, Throwable) - Method in class org.apache.openjpa.lib.log.NoneLogFactory.NoneLog
 
TRACE_STR - Static variable in class org.apache.openjpa.lib.log.LogFactoryImpl
 
transactional(Object, boolean, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
Make the given instances transactional.
transactional(Object, boolean, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
transactional(Object, boolean, OpCallbacks) - Method in interface org.apache.openjpa.kernel.StoreContext
Make the given object transactional.
transactional(Object, boolean) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
transactional(Object, boolean) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Make the given object transactional.
transactionalAll(Collection, boolean, OpCallbacks) - Method in class org.apache.openjpa.kernel.BrokerImpl
Make the given instances transactional.
transactionalAll(Collection, boolean, OpCallbacks) - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
transactionalAll(Collection, boolean, OpCallbacks) - Method in interface org.apache.openjpa.kernel.StoreContext
Make the given objects transactional.
transactionalAll(Collection, boolean) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
transactionalAll(Object[], boolean) - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
transactionalAll(Collection, boolean) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Make the given objects transactional.
transactionalAll(Object[], boolean) - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Make the given objects transactional.
TransactionEvent - Class in org.apache.openjpa.event
A transactional event.
TransactionEvent(Broker, int, Collection, Collection, Collection, Collection) - Constructor for class org.apache.openjpa.event.TransactionEvent
Constructor.
TransactionEventManager - Class in org.apache.openjpa.event
Manager that can be used to track and notify transaction listeners of transaction-related events.
TransactionEventManager() - Constructor for class org.apache.openjpa.event.TransactionEventManager
 
transactionIsolation - Variable in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
TransactionListener - Interface in org.apache.openjpa.event
Interface for listening to all TransactionEvents.
transactionMode - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
TransactionRequiredException - Exception in org.apache.openjpa.persistence
Transaction required.
TransactionRequiredException(Localizer.Message, Throwable[], Object, boolean) - Constructor for exception org.apache.openjpa.persistence.TransactionRequiredException
 
TransactionRequiredException(String, Throwable[], Object, boolean) - Constructor for exception org.apache.openjpa.persistence.TransactionRequiredException
 
transferStackTrace(Throwable, Throwable) - Static method in class org.apache.openjpa.lib.util.JavaVersions
Transfer the stack from one throwable to another, or return false if it cannot be done, possibly due to an unsupported Java version.
transform(ClassLoader, String, Class, ProtectionDomain, byte[]) - Method in class org.apache.openjpa.enhance.PCClassFileTransformer
 
TRANSIENT - Static variable in class org.apache.openjpa.kernel.PCState
Transient; unmanaged instance
translate(RuntimeException) - Method in class org.apache.openjpa.datacache.DelegatingDataCache
Translate the OpenJPA exception.
translate(RuntimeException) - Method in class org.apache.openjpa.datacache.DelegatingQueryCache
Translate the OpenJPA exception.
translate(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
Translate the user-given id or column.
translate(Object, Joins) - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
translate(RuntimeException) - Method in class org.apache.openjpa.kernel.DelegatingBroker
Translate the OpenJPA exception.
translate(RuntimeException) - Method in class org.apache.openjpa.kernel.DelegatingBrokerFactory
Translate the OpenJPA exception.
translate(RuntimeException) - Method in class org.apache.openjpa.kernel.DelegatingExtent
Translate the OpenJPA exception.
translate(RuntimeException) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
Translate the OpenJPA exception.
translate(RuntimeException) - Method in class org.apache.openjpa.kernel.DelegatingQuery
Translate the OpenJPA exception.
translate(RuntimeException) - Method in class org.apache.openjpa.kernel.DelegatingResultList
Translate the OpenJPA exception.
translate(RuntimeException) - Method in class org.apache.openjpa.kernel.DelegatingSeq
Translate the OpenJPA exception.
translate(RuntimeException) - Method in class org.apache.openjpa.kernel.StateManagerImpl
Translate the given exception based on the broker's implicit behavior.
translate(RuntimeException) - Method in interface org.apache.openjpa.util.RuntimeExceptionTranslator
Translate the given exception.
TRANSLATOR - Static variable in class org.apache.openjpa.persistence.PersistenceExceptions
 
traverse(FieldMetaData) - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
traverse(FieldMetaData) - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Traverse the given field to generate (possibly) a new configuration state.
traverse(FieldMetaData) - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
traverseJDBC(FieldMetaData) - Method in class org.apache.openjpa.jdbc.kernel.DelegatingJDBCFetchConfiguration
 
traverseJDBC(FieldMetaData) - Method in interface org.apache.openjpa.jdbc.kernel.JDBCFetchConfiguration
Convenience method to cast traversal to store-specific type.
traverseJDBC(FieldMetaData) - Method in class org.apache.openjpa.jdbc.kernel.JDBCFetchConfigurationImpl
 
traversePath(Path, String) - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
Traverse the given field in the given path.
traversePath(Path, String, boolean, boolean) - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
Traverse the given field in the given path.
traverseStaticField(Class, String) - Method in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
Return a constant containing the value of the given static field.
trim(Value, Value, Boolean) - Method in class org.apache.openjpa.jdbc.kernel.exps.JDBCExpressionFactory
 
trim(Value, Value, Boolean) - Method in interface org.apache.openjpa.kernel.exps.ExpressionFactory
Trims the specified specified trimChar from the specified value.
trim(Value, Value, Boolean) - Method in class org.apache.openjpa.kernel.exps.InMemoryExpressionFactory
 
trimBothFunction - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
trimLeadingFunction - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
trimTrailingFunction - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
TRUE - Static variable in class org.apache.openjpa.persistence.jdbc.AnnotationPersistenceMappingParser
 
TRUE - Static variable in annotation type org.apache.openjpa.persistence.jdbc.EmbeddedMapping
 
tryLock() - Method in interface org.apache.openjpa.lib.util.concurrent.Lock
Acquires the lock only if it is free at the time of invocation.
tryLock(long, TimeUnit) - Method in interface org.apache.openjpa.lib.util.concurrent.Lock
Acquires the lock if it is free within the given waiting time and the current thread has not been interrupted.
tryLock() - Method in class org.apache.openjpa.lib.util.concurrent.ReentrantLock
Acquires the lock only if it is not held by another thread at the time of invocation.
tryLock(long, TimeUnit) - Method in class org.apache.openjpa.lib.util.concurrent.ReentrantLock
Acquires the lock if it is not held by another thread within the given waiting time and the current thread has not been interrupted.
type - Variable in class org.apache.openjpa.jdbc.kernel.AbstractJDBCSeq
 
type(Object) - Method in class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer
 
Type - Annotation Type in org.apache.openjpa.persistence
Indicates the persistent type of a field, if different than the declared type.
type(Object) - Method in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Return the type constant for the given object based on its runtime class.
type - Variable in class org.apache.openjpa.util.OpenJPAId
 
TYPE_BOOLEAN - Static variable in interface org.apache.openjpa.kernel.exps.Literal
 
TYPE_CHAR_OBJ - Static variable in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
 
TYPE_CLASS_QUERIES - Static variable in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
 
TYPE_CLASS_SEQS - Static variable in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
 
TYPE_COLLECTION - Static variable in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
 
TYPE_CONTIGUOUS - Static variable in interface org.apache.openjpa.kernel.Seq
 
TYPE_CROSS - Static variable in class org.apache.openjpa.jdbc.sql.Join
 
TYPE_DEFAULT - Static variable in interface org.apache.openjpa.kernel.Seq
 
TYPE_FEATURE - Static variable in interface org.apache.openjpa.lib.conf.ProductDerivation
 
TYPE_INNER - Static variable in class org.apache.openjpa.jdbc.sql.Join
 
TYPE_JOINLESS - Static variable in interface org.apache.openjpa.jdbc.sql.Select
Constant indicating a select can be made without joins.
TYPE_MAP - Static variable in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
 
TYPE_META - Static variable in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
 
TYPE_NON_MAPPED_INTERFACE - Static variable in class org.apache.openjpa.meta.NonPersistentMetaData
 
TYPE_NONTRANSACTIONAL - Static variable in interface org.apache.openjpa.kernel.Seq
 
TYPE_NUMBER - Static variable in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
 
TYPE_NUMBER - Static variable in interface org.apache.openjpa.kernel.exps.Literal
 
TYPE_OBJECT - Static variable in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
 
TYPE_OUTER - Static variable in class org.apache.openjpa.jdbc.sql.Join
 
TYPE_PERSISTENCE_AWARE - Static variable in class org.apache.openjpa.meta.NonPersistentMetaData
 
TYPE_PRODUCT - Static variable in interface org.apache.openjpa.lib.conf.ProductDerivation
 
TYPE_PRODUCT_STORE - Static variable in interface org.apache.openjpa.conf.OpenJPAProductDerivation
 
TYPE_QUERY - Static variable in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
 
TYPE_SEQ - Static variable in class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
 
TYPE_SPEC - Static variable in interface org.apache.openjpa.conf.OpenJPAProductDerivation
 
TYPE_SPEC_STORE - Static variable in interface org.apache.openjpa.conf.OpenJPAProductDerivation
 
TYPE_SQ_STRING - Static variable in interface org.apache.openjpa.kernel.exps.Literal
 
TYPE_STORE - Static variable in interface org.apache.openjpa.conf.OpenJPAProductDerivation
 
TYPE_STRING - Static variable in class org.apache.openjpa.kernel.exps.AbstractExpressionBuilder
 
TYPE_STRING - Static variable in interface org.apache.openjpa.kernel.exps.Literal
 
TYPE_TRANSACTIONAL - Static variable in interface org.apache.openjpa.kernel.Seq
 
TYPE_TWO_PART - Static variable in interface org.apache.openjpa.jdbc.sql.Select
Constant indicating a two-part select and load.
TYPE_UNKNOWN - Static variable in interface org.apache.openjpa.kernel.exps.Literal
 
TypedProperties - Class in org.apache.openjpa.lib.util
A specialization of the Properties map type with added convenience methods to retrieve and set options as primitive values.
TypedProperties() - Constructor for class org.apache.openjpa.lib.util.TypedProperties
Default constructor.
TypedProperties(Properties) - Constructor for class org.apache.openjpa.lib.util.TypedProperties
Construct the properties instance with the given set of defaults.
typeMap - Variable in class org.apache.openjpa.jdbc.ant.ReverseMappingToolTask
 
typeMap - Variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool.Flags
 
types - Variable in class org.apache.openjpa.meta.AbstractMetaDataFactory
 
TypesChangedEvent - Class in org.apache.openjpa.datacache
An event indicating that instances of given persistent types have been modified.
TypesChangedEvent(Object, Collection) - Constructor for class org.apache.openjpa.datacache.TypesChangedEvent
Constructor.
TypesChangedListener - Interface in org.apache.openjpa.datacache
An entity that wishes to be notified when types change.

U

unalias(String) - Method in class org.apache.openjpa.lib.conf.Value
Unalias the given setting.
unalias(String, String[], boolean) - Method in class org.apache.openjpa.lib.conf.Value
Unalias the given setting.
uninversable(ValueMapping) - Static method in class org.apache.openjpa.jdbc.meta.strats.RelationStrategies
Return an exception indicating that the relation is invalid because it has is based on an inverse foreign key and has independent subclasses.
Union - Interface in org.apache.openjpa.jdbc.sql
SQL UNION.
Union.Selector - Interface in org.apache.openjpa.jdbc.sql
A callback used to create the selects in a SQL union.
Unique - Class in org.apache.openjpa.jdbc.schema
Represents a unique constraint.
Unique() - Constructor for class org.apache.openjpa.jdbc.schema.Unique
Default constructor.
Unique(String, Table) - Constructor for class org.apache.openjpa.jdbc.schema.Unique
Constructor.
Unique - Annotation Type in org.apache.openjpa.persistence.jdbc
Unique constraint definition.
uniqueIdentifierAsVarbinary - Variable in class org.apache.openjpa.jdbc.sql.SQLServerDictionary
Flag whether to treat UNIQUEIDENTIFIER as VARBINARY or VARCHAR
unjoinable(ValueMapping) - Static method in class org.apache.openjpa.jdbc.meta.strats.RelationStrategies
Return an exception indicating that we cannot join to the given relation.
unloadable(ValueMapping) - Static method in class org.apache.openjpa.jdbc.meta.strats.RelationStrategies
Return an exception indicating that the relation cannot be loaded because it has independent subclasses and does not represent a full oid.
unlock() - Method in class org.apache.openjpa.kernel.AbstractBrokerFactory
 
unlock() - Method in interface org.apache.openjpa.kernel.BrokerFactory
Release the internal lock.
unlock() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
unlock() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
unlock() - Method in class org.apache.openjpa.kernel.DelegatingBrokerFactory
 
unlock() - Method in class org.apache.openjpa.kernel.DelegatingExtent
 
unlock() - Method in class org.apache.openjpa.kernel.DelegatingFetchConfiguration
 
unlock() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
unlock() - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
unlock() - Method in interface org.apache.openjpa.kernel.Extent
Release the internal lock.
unlock() - Method in class org.apache.openjpa.kernel.ExtentImpl
 
unlock() - Method in interface org.apache.openjpa.kernel.FetchConfiguration
Release internal lock if multithreaded is true.
unlock() - Method in class org.apache.openjpa.kernel.FetchConfigurationImpl
 
unlock() - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
unlock() - Method in interface org.apache.openjpa.kernel.QueryContext
Unlock the query's internal lock.
unlock() - Method in class org.apache.openjpa.kernel.QueryImpl
 
unlock() - Method in class org.apache.openjpa.kernel.StateManagerImpl
Unlock the state manager.
unlock() - Method in interface org.apache.openjpa.kernel.StoreContext
Releases the internal lock.
unlock() - Method in interface org.apache.openjpa.lib.util.concurrent.Lock
Releases the lock.
unlock() - Method in class org.apache.openjpa.lib.util.concurrent.ReentrantLock
Attempts to release this lock.
unmappedTable(Table) - Method in class org.apache.openjpa.jdbc.meta.PropertiesReverseCustomizer
 
unmappedTable(Table) - Method in interface org.apache.openjpa.jdbc.meta.ReverseCustomizer
Notification that a table has gone unmapped.
unpin(Object) - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
unpin(QueryKey) - Method in class org.apache.openjpa.datacache.AbstractQueryCache
 
unpin(Object) - Method in interface org.apache.openjpa.datacache.DataCache
Unpin the value stored under oid from the cache.
unpin(Object) - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
unpin(QueryKey) - Method in class org.apache.openjpa.datacache.DelegatingQueryCache
 
unpin(QueryKey) - Method in interface org.apache.openjpa.datacache.QueryCache
Unpin the value stored under key into the cache.
unpin(Query) - Method in interface org.apache.openjpa.persistence.QueryResultCache
Unpin a previously-pinned query result.
unpin(Query) - Method in class org.apache.openjpa.persistence.QueryResultCacheImpl
 
unpin(Class, Object) - Method in interface org.apache.openjpa.persistence.StoreCache
Unpin the data for the given oid from the cache.
unpin(Class, Object) - Method in class org.apache.openjpa.persistence.StoreCacheImpl
 
unpin(Object) - Method in class org.apache.openjpa.util.CacheMap
Undo a pinning.
unpinAll(Collection) - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
unpinAll(Class, boolean) - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
unpinAll(Class, boolean) - Method in class org.apache.openjpa.datacache.ConcurrentDataCache
 
unpinAll(Collection) - Method in interface org.apache.openjpa.datacache.DataCache
Unpin all oids from the cache.
unpinAll(Class, boolean) - Method in interface org.apache.openjpa.datacache.DataCache
Unpin all oids associaed with the given type from the cache.
unpinAll(Collection) - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
unpinAll(Class, boolean) - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
unpinAll(Class, Object...) - Method in interface org.apache.openjpa.persistence.StoreCache
Unpin the data for the given oids from the cache.
unpinAll(Class, Collection) - Method in interface org.apache.openjpa.persistence.StoreCache
Unpin the data for the given oids from the cache.
unpinAll(Class, Object...) - Method in class org.apache.openjpa.persistence.StoreCacheImpl
 
unpinAll(Class, Collection) - Method in class org.apache.openjpa.persistence.StoreCacheImpl
 
unpinInternal(Object) - Method in class org.apache.openjpa.datacache.AbstractDataCache
Unpin an object from the cache.
unpinInternal(QueryKey) - Method in class org.apache.openjpa.datacache.AbstractQueryCache
Unpin an object from the cache.
unpinInternal(Object) - Method in class org.apache.openjpa.datacache.ConcurrentDataCache
 
unpinInternal(QueryKey) - Method in class org.apache.openjpa.datacache.ConcurrentQueryCache
 
UNRESTRICTED - Static variable in class org.apache.openjpa.jdbc.schema.ColumnIO
 
UNSUPPORTED - Static variable in interface org.apache.openjpa.jdbc.meta.Embeddable
 
UNSUPPORTED - Static variable in interface org.apache.openjpa.util.ExceptionInfo
 
UnsupportedException - Exception in org.apache.openjpa.util
Exception type for attempts to perform unsupported operations.
UnsupportedException() - Constructor for exception org.apache.openjpa.util.UnsupportedException
 
UnsupportedException(String) - Constructor for exception org.apache.openjpa.util.UnsupportedException
 
UnsupportedException(Localizer.Message) - Constructor for exception org.apache.openjpa.util.UnsupportedException
 
UnsupportedException(Localizer.Message, Throwable) - Constructor for exception org.apache.openjpa.util.UnsupportedException
 
UntypedPCValueHandler - Class in org.apache.openjpa.jdbc.meta.strats
Handler for unknown persistence-capable object fields that stores stringified oids.
UntypedPCValueHandler() - Constructor for class org.apache.openjpa.jdbc.meta.strats.UntypedPCValueHandler
 
unwrap(Class) - Static method in class org.apache.openjpa.kernel.Filters
Return the correct primitive type for the given class, if it is a wrapper.
update(DataCachePCData) - Method in class org.apache.openjpa.datacache.AbstractDataCache
 
update(DataCachePCData) - Method in interface org.apache.openjpa.datacache.DataCache
Update the cached value for the given instance.
update(DataCachePCData) - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
update(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
update(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.Discriminator
 
update(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
update(OpenJPAStateManager, JDBCStore, RowManager) - Method in interface org.apache.openjpa.jdbc.meta.Strategy
Set values for the mapping into the proper rows.
update(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractStrategy
 
update(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.ColumnVersionStrategy
 
update(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedFieldStrategy
 
update(OpenJPAStateManager, OpenJPAStateManager, JDBCStore, RowManager, Row) - Method in class org.apache.openjpa.jdbc.meta.strats.EmbedFieldStrategy
Update an embedded object.
update(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.FullClassStrategy
 
update(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
update(OpenJPAStateManager, Row) - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedBlobFieldStrategy
 
update(OpenJPAStateManager, Row) - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedByteArrayFieldStrategy
 
update(OpenJPAStateManager, Row) - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedCharArrayFieldStrategy
 
update(OpenJPAStateManager, Row) - Method in class org.apache.openjpa.jdbc.meta.strats.MaxEmbeddedClobFieldStrategy
 
update(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.NoneClassStrategy
 
update(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
update(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationFieldStrategy
 
update(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyInverseKeyFieldStrategy
 
update(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.RelationToManyTableFieldStrategy
 
update(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.StateComparisonVersionStrategy
 
update(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
update(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.strats.VerticalClassStrategy
 
update(OpenJPAStateManager, JDBCStore, RowManager) - Method in class org.apache.openjpa.jdbc.meta.Version
 
UpdateAction - Enum in org.apache.openjpa.persistence
Action to take when a field's value is changed.
updateAll() - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
updateAll(Object[]) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
updateAll(Map) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
updateAll() - Method in interface org.apache.openjpa.kernel.Query
Performs an update of the instances that are satisfied by the query.
updateAll(Object[]) - Method in interface org.apache.openjpa.kernel.Query
Performs an update of the instances that are satisfied by the query.
updateAll(Map) - Method in interface org.apache.openjpa.kernel.Query
Performs an update of the instances that are satisfied by the query.
updateAll() - Method in class org.apache.openjpa.kernel.QueryImpl
 
updateAll(Object[]) - Method in class org.apache.openjpa.kernel.QueryImpl
 
updateAll(Map) - Method in class org.apache.openjpa.kernel.QueryImpl
 
updateArray(int, Array) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateArray(String, Array) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateAsciiStream(int, InputStream, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateAsciiStream(String, InputStream, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateBigDecimal(int, BigDecimal) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateBigDecimal(String, BigDecimal) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateBinaryStream(int, InputStream, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateBinaryStream(String, InputStream, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateBlob(int, Blob) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateBlob(String, Blob) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateBoolean(int, boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateBoolean(String, boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateByte(int, byte) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateByte(String, byte) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateBytes(int, byte[]) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateBytes(String, byte[]) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateCharacterStream(int, Reader, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateCharacterStream(String, Reader, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateClob(int, Clob) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateClob(String, Clob) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateDate(int, Date) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateDate(String, Date) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateDouble(int, double) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateDouble(String, double) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateFloat(int, float) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateFloat(String, float) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateInMemory(StoreQuery.Executor, Object[]) - Method in class org.apache.openjpa.kernel.DelegatingQuery
 
updateInMemory(StoreQuery.Executor, Object[]) - Method in interface org.apache.openjpa.kernel.QueryContext
Helper method to update the objects found by executing a query on the given executor.
updateInMemory(StoreQuery.Executor, Object[]) - Method in class org.apache.openjpa.kernel.QueryImpl
 
updateInt(int, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateInt(String, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateLong(int, long) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateLong(String, long) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
UpdateManager - Interface in org.apache.openjpa.jdbc.kernel
This interface is used to customize the way that updates are made to database records.
updateManagerPlugin - Variable in class org.apache.openjpa.jdbc.conf.JDBCConfigurationImpl
 
updateNull(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateNull(String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateObject(int, Object, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateObject(int, Object) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateObject(String, Object, int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateObject(String, Object) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateRef(int, Ref) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateRef(String, Ref) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateRow() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updates - Variable in class org.apache.openjpa.kernel.exps.QueryExpressions
Map of FieldMetaData,Value for update statements.
updatesAreDetected(int) - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
updateShort(int, short) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateShort(String, short) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
UpdateStrategies - Class in org.apache.openjpa.meta
Strategies for persistent value updates.
UpdateStrategies() - Constructor for class org.apache.openjpa.meta.UpdateStrategies
 
updateString(int, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateString(String, String) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateTime(int, Time) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateTime(String, Time) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateTimestamp(int, Timestamp) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
updateTimestamp(String, Timestamp) - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
URLMetaDataIterator - Class in org.apache.openjpa.lib.meta
Iterator over the metadata resource represented by a URL.
URLMetaDataIterator(URL) - Constructor for class org.apache.openjpa.lib.meta.URLMetaDataIterator
Constructor; supply resource URL.
urls - Variable in class org.apache.openjpa.meta.AbstractCFMetaDataFactory
 
useBuiltinIdentityClass - Variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool.Flags
 
useClassCriteria() - Method in interface org.apache.openjpa.jdbc.meta.MappingDefaults
The default for whether relations use the related object's expected class as part of the join criteria.
useClassCriteria() - Method in class org.apache.openjpa.jdbc.meta.MappingDefaultsImpl
 
useClassCriteria() - Method in class org.apache.openjpa.jdbc.meta.NoneMappingDefaults
 
useClobs - Variable in class org.apache.openjpa.jdbc.sql.MySQLDictionary
Whether to use clobs.
useDataStoreIdentity - Variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool.Flags
 
useForeignKeyName - Variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool.Flags
 
useGetBestRowIdentifierForPrimaryKeys - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
useGetBytesForBlobs - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
useGetObjectForBlobs - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
useGetStringForClobs - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
useParent - Variable in class org.apache.openjpa.lib.ant.AbstractTask
 
USER - Static variable in interface org.apache.openjpa.util.ExceptionInfo
 
UserException - Exception in org.apache.openjpa.util
Base exception type for user errors.
UserException() - Constructor for exception org.apache.openjpa.util.UserException
 
UserException(String) - Constructor for exception org.apache.openjpa.util.UserException
 
UserException(Localizer.Message) - Constructor for exception org.apache.openjpa.util.UserException
 
UserException(Throwable) - Constructor for exception org.apache.openjpa.util.UserException
 
UserException(String, Throwable) - Constructor for exception org.apache.openjpa.util.UserException
 
UserException(Localizer.Message, Throwable) - Constructor for exception org.apache.openjpa.util.UserException
 
useSchemaName - Variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool.Flags
 
useSchemaName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
usesDetachedState() - Method in class org.apache.openjpa.meta.ClassMetaData
Whether an instance of this type has detached state.
useSetBytesForBlobs - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
useSetFormOfUseForUnicode - Variable in class org.apache.openjpa.jdbc.sql.OracleDictionary
If true, then OpenJPA will attempt to use the special OraclePreparedStatement.setFormOfUse method to configure statements that it detects are operating on unicode fields.
useSetStringForClobs - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
usesImplData(ClassMetaData) - Method in class org.apache.openjpa.enhance.PCDataGenerator
Whether the given type might have cacheable class-level impl data.
usesImplData(FieldMetaData) - Method in class org.apache.openjpa.enhance.PCDataGenerator
Whether the given field might have cacheable impl data.
usesImplData() - Method in class org.apache.openjpa.meta.FieldMetaData
Whether this field uses impl data in conjunction with standard field data when acting on a OpenJPAStateManager.
usesIntermediate(FieldMetaData) - Method in class org.apache.openjpa.enhance.PCDataGenerator
Whether the given field uses a cacheable intermediate value.
usesIntermediate() - Method in class org.apache.openjpa.meta.FieldMetaData
Whether this field uses intermediate data when loading/storing information through a OpenJPAStateManager.
usesLocalFilePerTable() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
usesLocalFiles() - Method in class org.apache.openjpa.lib.jdbc.DelegatingDatabaseMetaData
 
useTriggersForAutoAssign - Variable in class org.apache.openjpa.jdbc.sql.OracleDictionary
If true, then simulate auto-assigned values in Oracle by using a trigger that inserts a sequence value into the primary key value when a row is inserted.
Utils - Class in org.apache.openjpa.lib.util.concurrent
This class groups together the functionality of java.util.concurrent that cannot be fully and reliably implemented in backport, but for which some form of emulation is possible.
UUID_HEX - Static variable in class org.apache.openjpa.meta.ValueStrategies
"uuid-hex" value strategy.
UUID_HEX - Static variable in interface org.apache.openjpa.persistence.Generator
 
UUID_STRING - Static variable in class org.apache.openjpa.meta.ValueStrategies
"uuid-string" value strategy.
UUID_STRING - Static variable in interface org.apache.openjpa.persistence.Generator
 
UUIDGenerator - Class in org.apache.openjpa.lib.util
UUID value generator.
UUIDGenerator() - Constructor for class org.apache.openjpa.lib.util.UUIDGenerator
 
UUIDHexSeq - Class in org.apache.openjpa.kernel
Sequence for generating 32-character hex UUID strings.
UUIDStringSeq - Class in org.apache.openjpa.kernel
Sequence for generating 16-character UUID strings.

V

Val - Interface in org.apache.openjpa.jdbc.kernel.exps
A Value represents any non-operator in a query filter, including constants, variables, and object fields.
Val - Class in org.apache.openjpa.kernel.exps
An in-memory representation of a Value.
Val() - Constructor for class org.apache.openjpa.kernel.exps.Val
 
VALID - Static variable in class org.apache.openjpa.jdbc.sql.RowImpl
 
validate(StoreQuery) - Method in class org.apache.openjpa.kernel.AbstractStoreQuery.AbstractExecutor
 
validate(StoreQuery) - Method in interface org.apache.openjpa.kernel.StoreQuery.Executor
Validate components of query.
validate() - Method in class org.apache.openjpa.lib.conf.AbstractProductDerivation
 
validate() - Method in interface org.apache.openjpa.lib.conf.ProductDerivation
Ensure that this derivation is valid.
validate() - Method in class org.apache.openjpa.persistence.jdbc.JDBCPersistenceProductDerivation
 
validate() - Method in class org.apache.openjpa.persistence.PersistenceProductDerivation
 
VALIDATE_MAPPING - Static variable in class org.apache.openjpa.meta.MetaDataRepository
Bit flag to validate mappings.
VALIDATE_META - Static variable in class org.apache.openjpa.meta.MetaDataRepository
Bit flag to validate metadata.
VALIDATE_NONE - Static variable in class org.apache.openjpa.meta.MetaDataRepository
Constant to not validate any metadata.
VALIDATE_RUNTIME - Static variable in class org.apache.openjpa.meta.MetaDataRepository
Bit flag for runtime validation.
VALIDATE_UNENHANCED - Static variable in class org.apache.openjpa.meta.MetaDataRepository
Bit flag to validate unenhanced metadata only.
validateChanges() - Method in interface org.apache.openjpa.kernel.Broker
Validate the changes made in this transaction, reporting any optimistic violations, constraint violations, etc.
validateChanges() - Method in class org.apache.openjpa.kernel.BrokerImpl
 
validateChanges() - Method in class org.apache.openjpa.kernel.DelegatingBroker
 
validateChanges() - Method in class org.apache.openjpa.persistence.EntityManagerImpl
 
validateChanges() - Method in interface org.apache.openjpa.persistence.OpenJPAEntityManager
Validate the changes made in this transaction, reporting any optimistic violations, constraint violations, etc.
validateDataStoreExtensionPrefix(String) - Method in class org.apache.openjpa.jdbc.meta.ClassMapping
 
validateDataStoreExtensionPrefix(String) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
validateDataStoreExtensionPrefix(String) - Method in class org.apache.openjpa.meta.Extensions
Return true if extensions starting with the given official datastore prefix should be validated for this runtime.
validateExtensionKeys() - Method in class org.apache.openjpa.meta.Extensions
Helper method to issue warnings for any extensions that we recognize but do not use.
validateMapping(boolean) - Method in class org.apache.openjpa.meta.ClassMetaData
Validate mapping data.
validateMeta(boolean) - Method in class org.apache.openjpa.meta.ClassMetaData
Validate resolved metadata.
ValidatingErrorHandler - Class in org.apache.openjpa.lib.xml
ErrorHandler implementation which overrides the default behavior of ignoring parse errors to throw a SAXException instead.
ValidatingErrorHandler() - Constructor for class org.apache.openjpa.lib.xml.ValidatingErrorHandler
 
validationSQL - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
value - Variable in class org.apache.openjpa.jdbc.sql.Calendard
 
value - Variable in class org.apache.openjpa.jdbc.sql.Sized
 
Value - Interface in org.apache.openjpa.kernel.exps
Interface for any non-operator in a query filter, including constants, variables, and object fields.
Value - Class in org.apache.openjpa.lib.conf
A configuration value.
Value() - Constructor for class org.apache.openjpa.lib.conf.Value
Default constructor.
Value(String) - Constructor for class org.apache.openjpa.lib.conf.Value
Constructor.
value(Object) - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
Return the value of the given key.
valueChanged(Value) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
 
valueChanged() - Method in class org.apache.openjpa.lib.conf.Value
Subclasses should call this method when their inernal value changes.
valueChanged(Value) - Method in interface org.apache.openjpa.lib.conf.ValueListener
Callback used by Value objects to notify listener of change.
valueExpired(Object) - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
 
valueExpired(Object) - Method in class org.apache.openjpa.lib.util.ReferenceHashMap
 
valueExpired(Object) - Method in interface org.apache.openjpa.lib.util.ReferenceMap
Overridable callback for when a value reference expires.
ValueHandler - Interface in org.apache.openjpa.jdbc.meta
Maps a value to a relational schema.
ValueListener - Interface in org.apache.openjpa.lib.conf
Components can listen on Value objects for changes directly.
ValueMapDiscriminatorStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Maps metadata-given values to classes.
ValueMapDiscriminatorStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.ValueMapDiscriminatorStrategy
 
ValueMapping - Interface in org.apache.openjpa.jdbc.meta
Specialization of value metadata for relational databases.
ValueMappingImpl - Class in org.apache.openjpa.jdbc.meta
Standalone ValueMapping implementation.
ValueMappingImpl(FieldMapping) - Constructor for class org.apache.openjpa.jdbc.meta.ValueMappingImpl
Constructor.
ValueMappingInfo - Class in org.apache.openjpa.jdbc.meta
Information about the mapping from a field value to the schema, in raw form.
ValueMappingInfo() - Constructor for class org.apache.openjpa.jdbc.meta.ValueMappingInfo
 
ValueMetaData - Interface in org.apache.openjpa.meta
Holds metadata on a value; this could be a field value, key value, or element value.
ValueMetaDataImpl - Class in org.apache.openjpa.meta
Default ValueMetaData implementation.
ValueMetaDataImpl(FieldMetaData) - Constructor for class org.apache.openjpa.meta.ValueMetaDataImpl
 
valueOf(String) - Static method in enum org.apache.openjpa.persistence.jdbc.EagerFetchType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.openjpa.persistence.jdbc.ForeignKeyAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.openjpa.persistence.jdbc.NonpolymorphicType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.openjpa.persistence.MetaDataTag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.openjpa.persistence.PersistenceStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.openjpa.persistence.UpdateAction
Returns the enum constant of this type with the specified name.
values() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentHashMap
Returns a collection view of the values contained in this map.
values() - Method in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashMap
Returns a Collection view of the values contained in this HashMap.
values() - Static method in class org.apache.openjpa.lib.util.concurrent.TimeUnit
 
values() - Static method in enum org.apache.openjpa.persistence.jdbc.EagerFetchType
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.apache.openjpa.persistence.jdbc.ForeignKeyAction
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.apache.openjpa.persistence.jdbc.NonpolymorphicType
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.apache.openjpa.persistence.MetaDataTag
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.apache.openjpa.persistence.PersistenceStrategy
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.apache.openjpa.persistence.UpdateAction
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
values() - Method in class org.apache.openjpa.util.CacheMap
 
values() - Method in class org.apache.openjpa.util.ProxyHashMap
 
values() - Method in class org.apache.openjpa.util.ProxyHashtable
 
values() - Method in class org.apache.openjpa.util.ProxyProperties
 
values() - Method in class org.apache.openjpa.util.ProxyTreeMap
 
ValueStrategies - Class in org.apache.openjpa.meta
Strategies for persistent value generation.
ValueStrategies() - Constructor for class org.apache.openjpa.meta.ValueStrategies
 
ValueTableJDBCSeq - Class in org.apache.openjpa.jdbc.kernel
Specialization of the TableJDBCSeq that maintains multiple sequence counts.
ValueTableJDBCSeq() - Constructor for class org.apache.openjpa.jdbc.kernel.ValueTableJDBCSeq
 
varbinaryTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
varcharTypeName - Variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
VENDOR_DATADIRECT - Static variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
VENDOR_JTDS - Static variable in class org.apache.openjpa.jdbc.sql.SQLServerDictionary
 
VENDOR_MICROSOFT - Static variable in class org.apache.openjpa.jdbc.sql.SQLServerDictionary
 
VENDOR_NAME - Static variable in class org.apache.openjpa.conf.OpenJPAVersion
 
VENDOR_NETDIRECT - Static variable in class org.apache.openjpa.jdbc.sql.SQLServerDictionary
 
VENDOR_ORACLE - Static variable in class org.apache.openjpa.jdbc.sql.OracleDictionary
 
VENDOR_OTHER - Static variable in class org.apache.openjpa.jdbc.sql.DBDictionary
 
VERBOSE - Static variable in interface org.apache.openjpa.lib.meta.MetaDataSerializer
 
vers - Variable in class org.apache.openjpa.jdbc.meta.strats.AbstractVersionStrategy
The owning version.
Version - Class in org.apache.openjpa.jdbc.meta
Handles optimistic lock versioning for a class.
Version(ClassMapping) - Constructor for class org.apache.openjpa.jdbc.meta.Version
Constructor.
VERSION - Static variable in class org.apache.openjpa.lib.util.JavaVersions
Java version; one of 2, 3, 4, 5, 6, or 7.
VERSION_DIFFERENT - Static variable in interface org.apache.openjpa.kernel.StoreManager
 
VERSION_EARLIER - Static variable in interface org.apache.openjpa.kernel.StoreManager
 
VERSION_ID - Static variable in class org.apache.openjpa.conf.OpenJPAVersion
 
VERSION_LATER - Static variable in interface org.apache.openjpa.kernel.StoreManager
 
VERSION_NUMBER - Static variable in class org.apache.openjpa.conf.OpenJPAVersion
 
VERSION_SAME - Static variable in interface org.apache.openjpa.kernel.StoreManager
 
VersionColumn - Annotation Type in org.apache.openjpa.persistence.jdbc
Surrogate version column.
VersionColumns - Annotation Type in org.apache.openjpa.persistence.jdbc
Allows the specification of multiple version columns for complex versioning.
VersionLockManager - Class in org.apache.openjpa.kernel
LockManager implementation that provides support for version checking and version updating when locks are acquired.
VersionLockManager() - Constructor for class org.apache.openjpa.kernel.VersionLockManager
 
VersionMappingInfo - Class in org.apache.openjpa.jdbc.meta
Information about the mapping from a version indicator to the schema, in raw form.
VersionMappingInfo() - Constructor for class org.apache.openjpa.jdbc.meta.VersionMappingInfo
 
versionStrategy - Variable in class org.apache.openjpa.jdbc.meta.ReverseMappingTool.Flags
 
VersionStrategy - Interface in org.apache.openjpa.jdbc.meta
Handles optimistic lock versioning for a class.
VersionStrategy - Annotation Type in org.apache.openjpa.persistence.jdbc
Version mapping strategy.
VerticalClassStrategy - Class in org.apache.openjpa.jdbc.meta.strats
Mapping for subclasses that join to their superclass table.
VerticalClassStrategy() - Constructor for class org.apache.openjpa.jdbc.meta.strats.VerticalClassStrategy
 

W

WaitQueue - Class in org.apache.openjpa.lib.util.concurrent
Base class for internal queue classes for semaphores, etc.
WaitQueue() - Constructor for class org.apache.openjpa.lib.util.concurrent.WaitQueue
 
WaitQueue.QueuedSync - Interface in org.apache.openjpa.lib.util.concurrent
 
WaitQueue.WaitNode - Class in org.apache.openjpa.lib.util.concurrent
 
WaitQueue.WaitNode() - Constructor for class org.apache.openjpa.lib.util.concurrent.WaitQueue.WaitNode
 
warn(Object) - Method in class org.apache.openjpa.lib.log.AbstractLog
 
warn(Object, Throwable) - Method in class org.apache.openjpa.lib.log.AbstractLog
 
warn(Object) - Method in class org.apache.openjpa.lib.log.CommonsLogFactory.LogAdapter
 
warn(Object, Throwable) - Method in class org.apache.openjpa.lib.log.CommonsLogFactory.LogAdapter
 
WARN - Static variable in interface org.apache.openjpa.lib.log.Log
 
warn(Object) - Method in interface org.apache.openjpa.lib.log.Log
Write out a log message at the Log.WARN level with the stringification of o as the body of the message, also outputting t to the log.
warn(Object, Throwable) - Method in interface org.apache.openjpa.lib.log.Log
Write out a log message at the Log.WARN level with the stringification of o as the body of the message, also outputting t to the log.
warn(Object) - Method in class org.apache.openjpa.lib.log.Log4JLogFactory.LogAdapter
 
warn(Object, Throwable) - Method in class org.apache.openjpa.lib.log.Log4JLogFactory.LogAdapter
 
warn(Object) - Method in class org.apache.openjpa.lib.log.NoneLogFactory.NoneLog
 
warn(Object, Throwable) - Method in class org.apache.openjpa.lib.log.NoneLogFactory.NoneLog
 
WARN_STR - Static variable in class org.apache.openjpa.lib.log.LogFactoryImpl
 
warnConsistency(OpenJPAStateManager, FieldMetaData) - Method in class org.apache.openjpa.kernel.InverseManager
Log an inconsistency warning
warning(SAXParseException) - Method in class org.apache.openjpa.lib.xml.ValidatingErrorHandler
 
WASManagedRuntime - Class in org.apache.openjpa.ee
ManagedRuntime implementation that allows synchronization with a WebSphere managed transaction.
WASManagedRuntime() - Constructor for class org.apache.openjpa.ee.WASManagedRuntime
 
wasNull() - Method in class org.apache.openjpa.jdbc.sql.AbstractResult
 
wasNull() - Method in class org.apache.openjpa.jdbc.sql.MergedResult
 
wasNull() - Method in interface org.apache.openjpa.jdbc.sql.Result
Return true if the last value fetched was null.
wasNull() - Method in class org.apache.openjpa.jdbc.sql.ResultSetResult
 
wasNull() - Method in class org.apache.openjpa.lib.jdbc.DelegatingCallableStatement
 
wasNull() - Method in class org.apache.openjpa.lib.jdbc.DelegatingResultSet
 
WEAK - Static variable in class org.apache.openjpa.lib.util.concurrent.ConcurrentReferenceHashSet
Weak reference marker.
WEAK - Static variable in class org.apache.openjpa.lib.util.ReferenceHashSet
Weak reference marker.
WEAK - Static variable in interface org.apache.openjpa.lib.util.ReferenceMap
 
where(OpenJPAStateManager, JDBCStore, RowManager, Object) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
where(OpenJPAStateManager, JDBCStore, RowManager, Object) - Method in interface org.apache.openjpa.jdbc.meta.FieldStrategy
Add a WHERE condition to the row for this field such that the field's current DB value must equal the given previous value.
where(OpenJPAStateManager, JDBCStore, RowManager, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.AbstractFieldStrategy
 
where(OpenJPAStateManager, JDBCStore, RowManager, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.HandlerFieldStrategy
 
where(ValueMapping, Object, JDBCStore, Row, Column[]) - Static method in class org.apache.openjpa.jdbc.meta.strats.HandlerStrategies
Add where conditions to the given row.
where(OpenJPAStateManager, JDBCStore, RowManager, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.PrimitiveFieldStrategy
 
where(OpenJPAStateManager, JDBCStore, RowManager, Object) - Method in class org.apache.openjpa.jdbc.meta.strats.StringFieldStrategy
 
where(Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
where(SQLBuffer) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
where(SQLBuffer, Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
where(String) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
where(String, Joins) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
where(Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
Add the given where conditions.
where(SQLBuffer) - Method in interface org.apache.openjpa.jdbc.sql.Select
Add the given where conditions.
where(SQLBuffer, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
Add the given where conditions.
where(String) - Method in interface org.apache.openjpa.jdbc.sql.Select
Add the given where conditions.
where(String, Joins) - Method in interface org.apache.openjpa.jdbc.sql.Select
Add the given where conditions.
where(Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
where(SQLBuffer) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
where(SQLBuffer, Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
where(String) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
where(String, Joins) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
whereArray(Column, Array) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereArray(Column, Array) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereAsciiStream(Column, InputStream, int) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereAsciiStream(Column, InputStream, int) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereBigDecimal(Column, BigDecimal) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereBigDecimal(Column, BigDecimal) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereBigInteger(Column, BigInteger) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereBigInteger(Column, BigInteger) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereBinaryStream(Column, InputStream, int) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereBinaryStream(Column, InputStream, int) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereBlob(Column, Blob) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereBlob(Column, Blob) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereBoolean(Column, boolean) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereBoolean(Column, boolean) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereByte(Column, byte) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereByte(Column, byte) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereBytes(Column, byte[]) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereBytes(Column, byte[]) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereCalendar(Column, Calendar) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereCalendar(Column, Calendar) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereChar(Column, char) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereChar(Column, char) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereCharacterStream(Column, Reader, int) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereCharacterStream(Column, Reader, int) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereClob(Column, Clob) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereClob(Column, Clob) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereClone(int) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
whereClone(int) - Method in interface org.apache.openjpa.jdbc.sql.Select
Return a SELECT with the same joins and where conditions as this one.
whereClone(int) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
whereDate(Column, Date) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereDate(Column, Date, Calendar) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereDate(Column, Date) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereDate(Column, Date, Calendar) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereDouble(Column, double) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereDouble(Column, double) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereFloat(Column, float) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereFloat(Column, float) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereForeignKey(Row, OpenJPAStateManager) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
 
whereForeignKey(Row, OpenJPAStateManager) - Method in interface org.apache.openjpa.jdbc.meta.ValueMapping
Sets this value's foreign key to the given related object.
whereForeignKey(Row, OpenJPAStateManager) - Method in class org.apache.openjpa.jdbc.meta.ValueMappingImpl
 
whereForeignKey(ForeignKey, Object, ClassMapping, JDBCStore) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
whereForeignKey(ForeignKey, OpenJPAStateManager) - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
 
whereForeignKey(ForeignKey, OpenJPAStateManager) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the foreign key equality criteria to link to the given object.
whereForeignKey(ForeignKey, OpenJPAStateManager) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereForeignKey(ForeignKey, Object, ClassMapping, JDBCStore) - Method in interface org.apache.openjpa.jdbc.sql.Select
Add where conditions setting the given foreign key to the given oid values.
whereForeignKey(ForeignKey, Object, ClassMapping, JDBCStore) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
whereInt(Column, int) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereInt(Column, int) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereLocale(Column, Locale) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereLocale(Column, Locale) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereLong(Column, long) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereLong(Column, long) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereNull(Column) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereNull(Column) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereNumber(Column, Number) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereNumber(Column, Number) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereObject(Column, Object) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereObject(Column, Object) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereObject(Column, Object, int) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
All where column methods delegate to this one.
wherePrimaryKey(Select, OpenJPAStateManager, JDBCStore) - Method in class org.apache.openjpa.jdbc.meta.FieldMapping
Add a wherePrimaryKey or whereForeignKey condition to the given select, depending on whether we have a join foreign key.
wherePrimaryKey(Object, ClassMapping, JDBCStore) - Method in class org.apache.openjpa.jdbc.sql.LogicalUnion.UnionSelect
 
wherePrimaryKey(OpenJPAStateManager) - Method in class org.apache.openjpa.jdbc.sql.PrimaryRow
 
wherePrimaryKey(OpenJPAStateManager) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set the primary key equality criteria for this row.
wherePrimaryKey(OpenJPAStateManager) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
wherePrimaryKey(Object, ClassMapping, JDBCStore) - Method in interface org.apache.openjpa.jdbc.sql.Select
Add where conditions setting the mapping's primary key to the given oid values.
wherePrimaryKey(Object, ClassMapping, JDBCStore) - Method in class org.apache.openjpa.jdbc.sql.SelectImpl
 
whereRaw(Column, String) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set a DB understood where condition for the given column.
whereRaw(Column, String) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereShort(Column, short) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereShort(Column, short) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereString(Column, String) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereString(Column, String) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereTime(Column, Time, Calendar) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereTime(Column, Time, Calendar) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
whereTimestamp(Column, Timestamp, Calendar) - Method in interface org.apache.openjpa.jdbc.sql.Row
Set an equality condition on the value of the given column in this row.
whereTimestamp(Column, Timestamp, Calendar) - Method in class org.apache.openjpa.jdbc.sql.RowImpl
 
WildcardMatch - Class in org.apache.openjpa.kernel.exps
Deprecated. Use matches() instead.
WildcardMatch() - Constructor for class org.apache.openjpa.kernel.exps.WildcardMatch
Deprecated.  
WindowResultList - Class in org.apache.openjpa.lib.rop
ResultList implementation that uses a forward-scrolling window of results.
WindowResultList(ResultObjectProvider) - Constructor for class org.apache.openjpa.lib.rop.WindowResultList
 
WindowResultList(ResultObjectProvider, int) - Constructor for class org.apache.openjpa.lib.rop.WindowResultList
 
WLSManagedRuntime - Class in org.apache.openjpa.ee
ManagedRuntime implementation that directly accesses the transaction manager via WebLogic Server helper classes.
WLSManagedRuntime() - Constructor for class org.apache.openjpa.ee.WLSManagedRuntime
 
wrap(Class) - Static method in class org.apache.openjpa.kernel.Filters
Return the correct wrapper type for the given class.
wrapResult(ResultSet, boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingPreparedStatement
 
wrapResult(ResultSet, boolean) - Method in class org.apache.openjpa.lib.jdbc.DelegatingStatement
 
write(BCClass) - Method in interface org.apache.openjpa.lib.util.BytecodeWriter
 
write(OutputStream) - Method in class org.apache.openjpa.lib.util.ParameterTemplate
Write the internal value template with all parameters substituted with their current values.
write(Writer) - Method in class org.apache.openjpa.lib.util.ParameterTemplate
Write the internal value template with all parameters substituted with their current values.
write(File) - Method in class org.apache.openjpa.lib.util.ParameterTemplate
Write the internal value template with all parameters substituted with their current values.
write(char[], int, int) - Method in class org.apache.openjpa.lib.xml.XMLWriter
 
write(String, int, int) - Method in class org.apache.openjpa.lib.xml.XMLWriter
 
write(int) - Method in class org.apache.openjpa.lib.xml.XMLWriter
 
writeCode() - Method in class org.apache.openjpa.enhance.CodeGenerator
Write the generated code to the proper file.
writeCode(Writer) - Method in class org.apache.openjpa.enhance.CodeGenerator
Write the code to the specified Writer.
writeDataValue(Writer, int, Object) - Method in class org.apache.openjpa.xmlstore.XMLFileHandler
Write out the data value.
writeDetached(ObjectOutput) - Method in interface org.apache.openjpa.enhance.StateManager
Write detached state object and detached state manager to the given stream.
writeDetached(ObjectOutput) - Method in class org.apache.openjpa.kernel.DetachedStateManager
 
writeDetached(ObjectOutput) - Method in class org.apache.openjpa.kernel.DetachedValueStateManager
 
writeDetached(ObjectOutput) - Method in class org.apache.openjpa.kernel.ObjectIdStateManager
 
writeDetached(ObjectOutput) - Method in class org.apache.openjpa.kernel.StateManagerImpl
 
writeExternal(ObjectOutput) - Method in class org.apache.openjpa.datacache.QueryKey
 
writeExternal(ObjectOutput) - Method in class org.apache.openjpa.event.RemoteCommitEvent
 
writeExternal(ObjectOutput) - Method in class org.apache.openjpa.lib.conf.ConfigurationImpl
Implementation of the Externalizable interface to write the properties returned by ConfigurationImpl.toProperties(boolean).
writeLock() - Method in class org.apache.openjpa.datacache.ConcurrentDataCache
 
writeLock() - Method in class org.apache.openjpa.datacache.ConcurrentQueryCache
 
writeLock() - Method in interface org.apache.openjpa.datacache.DataCache
Obtain a write lock on the cache.
writeLock() - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
writeLock() - Method in class org.apache.openjpa.datacache.DelegatingQueryCache
 
writeLock() - Method in interface org.apache.openjpa.datacache.QueryCache
Obtain a write lock on the cache.
writeLock() - Method in class org.apache.openjpa.util.CacheMap
Acquire write lock.
writeLockLevel - Variable in class org.apache.openjpa.conf.OpenJPAConfigurationImpl
 
writeLockLevel - Variable in class org.apache.openjpa.kernel.FetchConfigurationImpl.ConfigurationState
 
writer - Variable in class org.apache.openjpa.jdbc.schema.SchemaTool.Flags
 
writer - Variable in class org.apache.openjpa.meta.MetaDataTool.Flags
 
writeReplace() - Method in class org.apache.openjpa.datacache.QueryCacheStoreQuery.CachedList
 
writeReplace() - Method in class org.apache.openjpa.datacache.QueryCacheStoreQuery
 
writeReplace() - Method in class org.apache.openjpa.kernel.DelegatingResultList
Writes delegate, which may in turn write a normal list.
writeReplace() - Method in class org.apache.openjpa.kernel.QueryImpl.RemoveOnCloseResultList
 
writeReplace() - Method in class org.apache.openjpa.lib.rop.LazyForwardResultList
 
writeReplace() - Method in class org.apache.openjpa.lib.rop.ListResultList
 
writeReplace() - Method in class org.apache.openjpa.lib.rop.RandomAccessResultList
 
writeReplace() - Method in class org.apache.openjpa.lib.rop.SimpleResultList
 
writeReplace() - Method in class org.apache.openjpa.lib.rop.WindowResultList
 
writeReplace() - Method in class org.apache.openjpa.util.AbstractLRSProxyCollection
 
writeReplace() - Method in class org.apache.openjpa.util.AbstractLRSProxyMap
 
writeReplace() - Method in class org.apache.openjpa.util.ProxyArrayList
 
writeReplace() - Method in class org.apache.openjpa.util.ProxyGregorianCalendar
 
writeReplace() - Method in class org.apache.openjpa.util.ProxyHashMap
 
writeReplace() - Method in class org.apache.openjpa.util.ProxyHashSet
 
writeReplace() - Method in class org.apache.openjpa.util.ProxyHashtable
 
writeReplace() - Method in class org.apache.openjpa.util.ProxyLinkedList
 
writeReplace() - Method in class org.apache.openjpa.util.ProxyProperties
 
writeReplace() - Method in class org.apache.openjpa.util.ProxySQLDate
 
writeReplace() - Method in class org.apache.openjpa.util.ProxyTime
 
writeReplace() - Method in class org.apache.openjpa.util.ProxyTimestamp
 
writeReplace() - Method in class org.apache.openjpa.util.ProxyTreeMap
 
writeReplace() - Method in class org.apache.openjpa.util.ProxyTreeSet
 
writeReplace() - Method in class org.apache.openjpa.util.ProxyUtilDate
 
writeReplace() - Method in class org.apache.openjpa.util.ProxyVector
 
writeSchemaColumn(String) - Method in class org.apache.openjpa.jdbc.schema.TableSchemaFactory
Writes the schema as a string to the database.
writeUnlock() - Method in class org.apache.openjpa.datacache.ConcurrentDataCache
 
writeUnlock() - Method in class org.apache.openjpa.datacache.ConcurrentQueryCache
 
writeUnlock() - Method in interface org.apache.openjpa.datacache.DataCache
Release the write lock on the cache.
writeUnlock() - Method in class org.apache.openjpa.datacache.DelegatingDataCache
 
writeUnlock() - Method in class org.apache.openjpa.datacache.DelegatingQueryCache
 
writeUnlock() - Method in interface org.apache.openjpa.datacache.QueryCache
Release the write lock on the cache.
writeUnlock() - Method in class org.apache.openjpa.util.CacheMap
Release write lock.

X

XJoinColumn - Annotation Type in org.apache.openjpa.persistence.jdbc
Extended join column.
XJoinColumns - Annotation Type in org.apache.openjpa.persistence.jdbc
Allows the specification of multiple columns for compound joins.
XMLConfiguration - Class in org.apache.openjpa.xmlstore
Configuration implementation for the XML file store.
XMLConfiguration() - Constructor for class org.apache.openjpa.xmlstore.XMLConfiguration
Default constructor.
XMLFactory - Class in org.apache.openjpa.lib.xml
The XMLFactory produces validating and non-validating DOM level 2 and SAX level 2 parsers and XSL transformers through JAXP.
XMLFactory() - Constructor for class org.apache.openjpa.lib.xml.XMLFactory
 
XMLFileHandler - Class in org.apache.openjpa.xmlstore
Stores ObjectData objects by serializing a collection of them into and out of an XML file.
XMLFileHandler(XMLConfiguration) - Constructor for class org.apache.openjpa.xmlstore.XMLFileHandler
Constructor; supply configuration.
XMLMetaDataParser - Class in org.apache.openjpa.lib.meta
Custom SAX parser used by the system to quickly parse metadata files.
XMLMetaDataParser() - Constructor for class org.apache.openjpa.lib.meta.XMLMetaDataParser
 
XMLMetaDataSerializer - Class in org.apache.openjpa.lib.meta
Abstract base type for serlializers that transfer groups of objects to XML.
XMLMetaDataSerializer() - Constructor for class org.apache.openjpa.lib.meta.XMLMetaDataSerializer
 
XMLPersistenceMappingParser - Class in org.apache.openjpa.persistence.jdbc
Custom SAX parser used by the system to parse persistence mapping files.
XMLPersistenceMappingParser(JDBCConfiguration) - Constructor for class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingParser
Constructor; supply configuration.
XMLPersistenceMappingSerializer - Class in org.apache.openjpa.persistence.jdbc
Serializes persistence mapping to XML.
XMLPersistenceMappingSerializer(JDBCConfiguration) - Constructor for class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer
Constructor.
XMLPersistenceMappingSerializer.MappingSerializationComparator - Class in org.apache.openjpa.persistence.jdbc
Extends XMLPersistenceMappingSerializer.MappingSerializationComparator for store-specific tags such as <sql-result-set-mapping>.
XMLPersistenceMappingSerializer.MappingSerializationComparator() - Constructor for class org.apache.openjpa.persistence.jdbc.XMLPersistenceMappingSerializer.MappingSerializationComparator
 
XMLPersistenceMetaDataParser - Class in org.apache.openjpa.persistence
Custom SAX parser used by the system to quickly parse persistence i metadata files.
XMLPersistenceMetaDataParser(OpenJPAConfiguration) - Constructor for class org.apache.openjpa.persistence.XMLPersistenceMetaDataParser
Constructor; supply configuration.
XMLPersistenceMetaDataSerializer - Class in org.apache.openjpa.persistence
Serializes persistence metadata back to XML.
XMLPersistenceMetaDataSerializer(OpenJPAConfiguration) - Constructor for class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer
Constructor.
XMLPersistenceMetaDataSerializer.SerializationComparator - Class in org.apache.openjpa.persistence
Compares clases, sequences, and queries to order them for serialization.
XMLPersistenceMetaDataSerializer.SerializationComparator() - Constructor for class org.apache.openjpa.persistence.XMLPersistenceMetaDataSerializer.SerializationComparator
 
XMLSchemaParser - Class in org.apache.openjpa.jdbc.schema
Custom SAX parser used to parse Schema objects.
XMLSchemaParser(JDBCConfiguration) - Constructor for class org.apache.openjpa.jdbc.schema.XMLSchemaParser
Constructor.
XMLSchemaSerializer - Class in org.apache.openjpa.jdbc.schema
Serializes Schemas to XML matching the document type definition defined by the XMLSchemaParser.
XMLSchemaSerializer(JDBCConfiguration) - Constructor for class org.apache.openjpa.jdbc.schema.XMLSchemaSerializer
Constructor.
XMLStore - Class in org.apache.openjpa.xmlstore
Represents a store of object data encoded in XML.
XMLStore(XMLConfiguration) - Constructor for class org.apache.openjpa.xmlstore.XMLStore
Constructor; supply configuration.
XMLStoreManager - Class in org.apache.openjpa.xmlstore
Store manager to a back-end consisting of XML files.
XMLStoreManager() - Constructor for class org.apache.openjpa.xmlstore.XMLStoreManager
 
XMLWriter - Class in org.apache.openjpa.lib.xml
The XMLWriter is a writer type for pretty-printing XML.
XMLWriter(Writer) - Constructor for class org.apache.openjpa.lib.xml.XMLWriter
Construct an XMLWriter that will write to the given stream.
XSecondaryTable - Annotation Type in org.apache.openjpa.persistence.jdbc
Extended secondary table.
XSecondaryTables - Annotation Type in org.apache.openjpa.persistence.jdbc
Allows the specification of multiple secondary tables.
XTable - Annotation Type in org.apache.openjpa.persistence.jdbc
Extended table.

Z

ZipFileMetaDataIterator - Class in org.apache.openjpa.lib.meta
Iterator over all metadata resources in a given zip file.
ZipFileMetaDataIterator(URL, MetaDataFilter) - Constructor for class org.apache.openjpa.lib.meta.ZipFileMetaDataIterator
Constructor; supply zip/jar URL and optional file filter.
ZipFileMetaDataIterator(ZipFile, MetaDataFilter) - Constructor for class org.apache.openjpa.lib.meta.ZipFileMetaDataIterator
Constructor; supply zip file and optional file filter.
ZipStreamMetaDataIterator - Class in org.apache.openjpa.lib.meta
Iterator over all metadata resources in a given zip input stream.
ZipStreamMetaDataIterator(ZipInputStream, MetaDataFilter) - Constructor for class org.apache.openjpa.lib.meta.ZipStreamMetaDataIterator
Constructor; supply zip stream and optional metadata filter.

_

_constsPK - Variable in class org.apache.openjpa.jdbc.schema.ForeignKey
 

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 _

Copyright © 2006 Apache Software Foundation. All Rights Reserved.